ClickHouse/src/Common
2023-08-22 17:05:14 +02:00
..
benchmarks Ditch tons of garbage 2023-08-09 02:19:02 +02:00
Config Merge pull request #52767 from ClickHouse/client-allow-yaml 2023-08-12 03:05:08 +03:00
examples Merge branch 'master' into feature/mergetree-checksum-big-endian-support 2023-08-10 10:21:34 -04:00
HashTable Merge pull request #53556 from ClibMouse/feature/big-endian-UUID-correction 2023-08-22 11:57:44 +02:00
JSONParsers Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
mysqlxx Add more logging and touch test for materialize mysql 2023-07-31 14:32:09 +02:00
NamedCollections Continue on garbage removal 2023-08-09 02:58:12 +02:00
StringUtils Preparation for libcxx(abi), llvm, clang-tidy 16 2023-03-19 17:25:41 +00:00
tests Whitespaces 2023-08-22 14:09:38 +02:00
ZooKeeper Fixed for using failed_op_index before it is initialized 2023-08-18 11:19:35 +02:00
ActionBlocker.h
ActionLock.cpp clang-tidy check performance-noexcept-move-constructor fix 2022-03-02 18:15:27 +00:00
ActionLock.h clang-tidy check performance-noexcept-move-constructor fix 2022-03-02 18:15:27 +00:00
AlignedBuffer.cpp
AlignedBuffer.h Fix clang-tidy warnings in Common folder 2022-03-14 18:17:35 +00:00
AllocationTrace.h Update AllocationTrace.h 2023-08-01 17:14:49 +00:00
Allocator_fwd.h Revert "Remove mmap/mremap/munmap from Allocator.h" (#52589) 2023-07-26 18:30:18 +02:00
Allocator.cpp Revert "Remove mmap/mremap/munmap from Allocator.h" (#52589) 2023-07-26 18:30:18 +02:00
Allocator.h Fixing a test. 2023-08-03 09:35:45 +00:00
AllocatorWithMemoryTracking.h Revert "Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2023-01-16 15:10:31 +01:00
Arena.h Arena used bytes 2023-04-24 10:46:23 +02:00
ArenaAllocator.h Check for #pragma once in headers 2020-10-10 21:37:02 +03:00
ArenaUtils.h Fix clang-tidy warnings in Common folder 2022-03-14 18:17:35 +00:00
ArenaWithFreeLists.h Don't count unreserved bytes in Arenas as read_bytes 2023-04-13 12:43:24 +02:00
ArrayCache.h Fix clang-tidy warnings (from clang-15) 2022-09-10 21:38:35 +02:00
assert_cast.h Cosmetics 2023-06-28 18:35:27 +00:00
assertProcessUserMatchesDataOwner.cpp Move common code 2023-05-19 16:23:56 +02:00
assertProcessUserMatchesDataOwner.h Fixed tests 2023-06-20 11:42:22 +03:00
AsynchronousMetrics.cpp Normalize with respect to CGroups 2023-06-10 18:03:17 +02:00
AsynchronousMetrics.h Minor improvements in CGroup awareness. 2023-05-31 01:52:02 -07:00
AsyncLoader.cpp Update AsyncLoader.cpp 2023-06-21 20:25:10 +03:00
AsyncLoader.h fix flaky AsyncLoader destructor 2023-06-21 15:16:18 +00:00
AsyncTaskExecutor.cpp Attempt to fix assert in tsan with fibers 2023-07-18 11:06:16 +00:00
AsyncTaskExecutor.h Merge pull request #50034 from Avogar/fiber-local-var-2 2023-05-30 17:50:31 +02:00
atomicRename.cpp Use __powerpc64__ over __ppc64__ (clang 16 stops declaring __ppc64__) 2023-05-09 12:20:50 +02:00
atomicRename.h Support atomic replace under OSX 2022-04-11 14:32:55 +02:00
Base58.cpp Add functio ntryBase58Decode() 2022-09-27 10:18:36 +00:00
Base58.h Add functio ntryBase58Decode() 2022-09-27 10:18:36 +00:00
Base64.cpp Address PR comments 2022-09-01 07:56:06 +00:00
Base64.h Improve remove recursive 2022-09-01 12:16:13 +00:00
BinStringDecodeHelper.h use std::lerp, constexpr hex.h 2023-03-07 22:50:17 +00:00
BitHelpers.h typename spelling error: unsigedT -> UnsignedT 2023-04-21 08:51:58 +08:00
BridgeProtocolVersion.h Add simple versioning to the *-bridge-to-server protocol 2022-08-08 19:40:37 +00:00
CacheBase.h Cosmetics 2023-08-21 14:08:44 +00:00
CancelableSharedMutex.cpp fix try_shared_lock() in SharedMutex and CancelableSharedMutex 2023-01-24 14:36:07 +00:00
CancelableSharedMutex.h fix darwin build 2023-01-11 12:23:33 +00:00
CancelToken.cpp Apply some CTAD 2023-03-02 13:36:47 +00:00
CancelToken.h make style-check happy 2023-01-10 01:26:59 +00:00
CaresPTRResolver.cpp init and destroy ares channel on demand.. 2023-07-26 17:09:23 -03:00
CaresPTRResolver.h init and destroy ares channel on demand.. 2023-07-26 17:09:23 -03:00
checkSSLReturnCode.cpp Fix typo 2023-05-30 16:25:17 +02:00
checkSSLReturnCode.h Fix build 2023-05-28 15:46:32 +02:00
checkStackSize.cpp Allow running in a stripped chroot 2023-06-28 11:56:11 +02:00
checkStackSize.h
clearPasswordFromCommandLine.cpp Enable clang-tidy modernize-deprecated-headers & hicpp-deprecated-headers 2022-05-09 08:23:33 +02:00
clearPasswordFromCommandLine.h
clickhouse_malloc.cpp Revert "Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2023-01-16 15:10:31 +01:00
ClickHouseRevision.cpp Generate config_version.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
ClickHouseRevision.h straighten the protocol version 2020-09-17 17:37:29 +03:00
CMakeLists.txt Use incbin for resources, part 1 2023-07-23 06:11:03 +02:00
ColumnsHashing.h Optimize one nullable key aggregate performance (#45772) 2023-03-02 21:01:52 +01:00
ColumnsHashingImpl.h Optimize one nullable key aggregate performance (#45772) 2023-03-02 21:01:52 +01:00
CombinedCardinalityEstimator.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
CompactArray.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
Concepts.h Incorporate more review feedback 2023-04-05 19:43:30 +00:00
ConcurrencyControl.cpp Fix typo: "as much slots" -> "as many slots" 2023-05-07 04:42:46 +02:00
ConcurrencyControl.h Fix typo: "as much slots" -> "as many slots" 2023-05-07 04:42:46 +02:00
ConcurrentBoundedQueue.h Check for punctuation 2023-07-25 06:10:04 +02:00
config_version.cpp.in Better usage of ccache 2023-08-09 05:02:50 +02:00
config_version.h.in Better usage of ccache 2023-08-09 05:02:50 +02:00
config.h.in More fixes 2023-07-28 13:00:35 +00:00
CounterInFile.h Ditch tons of garbage 2023-08-09 02:19:02 +02:00
COW.h mark all operators bool() as explicit 2022-05-20 15:29:54 +00:00
CpuId.h ColumnVector: re-enable AVX512_VBMI/AVX512_VBMI2 optimized filter and index (#41765) 2022-10-24 23:11:46 +02:00
createHardLink.cpp Enable clang-tidy modernize-deprecated-headers & hicpp-deprecated-headers 2022-05-09 08:23:33 +02:00
createHardLink.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
CurrentMemoryTracker.cpp Fixing a test. 2023-08-03 09:35:45 +00:00
CurrentMemoryTracker.h Fixing a test. 2023-08-03 09:35:45 +00:00
CurrentMetrics.cpp Better 2023-08-10 14:04:19 +02:00
CurrentMetrics.h Use StrongTypedef for CurrentMetrics to avoid possible incorrect usage 2023-04-01 16:01:33 +02:00
CurrentThread.cpp Rename TaskStatsInfoGetter into NetlinkMetricsProvider 2023-07-21 06:48:18 +02:00
CurrentThread.h Merge remote-tracking branch 'origin/master' into revert-47476-revert_46622 2023-04-21 16:40:04 +00:00
DateLUT.cpp changes requested in review 2023-06-16 02:16:04 +02:00
DateLUT.h small 2023-06-20 03:21:03 +02:00
DateLUTImpl.cpp less exceptions with runtime format string 2023-08-14 21:45:59 +02:00
DateLUTImpl.h Merge branch 'master' of github.com:ClickHouse/ClickHouse into ADQM-810-dev 2023-05-29 08:26:26 +00:00
DNSPTRResolver.h Fix CaresPTRResolver not reading hosts file 2022-08-29 15:11:39 -03:00
DNSPTRResolverProvider.cpp what 2022-10-21 14:43:08 -03:00
DNSPTRResolverProvider.h Force use of c-ares inet_net_pton and style adjustments 2022-07-13 11:51:43 -03:00
DNSResolver.cpp Cosmetics 2023-08-21 14:08:44 +00:00
DNSResolver.h less exceptions with runtime format string 2023-08-14 21:45:59 +02:00
Dwarf.cpp Remove PVS-Studio 2023-02-19 23:30:05 +01:00
Dwarf.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
ElapsedTimeProfileEventIncrement.h Resubmit prefetches 2023-02-08 21:26:24 +01:00
Elf.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
Elf.h Minor follow-up 2022-06-14 08:52:13 +00:00
Epoll.cpp Various reactions when executable stderr has data 2023-08-18 15:38:45 +08:00
Epoll.h Various reactions when executable stderr has data 2023-08-18 15:38:45 +08:00
ErrorCodes.cpp Fix wrong error code "BAD_GET" 2023-08-02 23:16:06 +02:00
ErrorCodes.h Support for Clang Thread Safety Analysis (TSA) 2022-06-20 16:13:25 +02:00
ErrorHandlers.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
escapeForFileName.cpp use std::lerp, constexpr hex.h 2023-03-07 22:50:17 +00:00
escapeForFileName.h
EventCounter.h
EventFD.cpp Check return value of ::close() 2023-02-07 11:28:22 +01:00
EventFD.h Review fixes. 2022-11-24 16:04:35 +00:00
EventNotifier.cpp Try to make MergeTreeRestartingThread more reactive in case of expired sessions (#41092) 2022-09-23 14:40:04 +02:00
EventNotifier.h Ditch tons of garbage 2023-08-09 02:19:02 +02:00
EventRateMeter.h typo 2022-11-17 16:20:21 +00:00
Exception.cpp Add a test that clickhouse-client or local do not throw/catch on startup 2023-07-17 00:06:58 +02:00
Exception.h Merge branch 'master' into concept 2023-08-06 21:43:26 +08:00
ExponentiallySmoothedCounter.h Fix clang-tidy warnings in Common folder 2022-03-14 18:17:35 +00:00
ExternalLoaderStatus.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
ExternalModelInfo.h chore: restore SYSTEM RELOAD MODEL(S) and moniting view SYSTEM.MODELS 2022-09-12 19:33:02 +00:00
FailPoint.cpp Correctly handle totals and extremes with DelayedSource 2023-08-21 14:07:59 +00:00
FailPoint.h address comments 2023-05-10 13:56:17 +02:00
Fiber.h Make better 2023-05-22 18:22:05 +00:00
FiberStack.h Revert "Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2023-01-16 15:10:31 +01:00
FieldVisitorConvertToNumber.h Merge pull request #41976 from kssenii/allow-single-disk-instead-of-storage-policy 2023-02-10 21:38:50 +01:00
FieldVisitorDump.cpp Parquet filter pushdown 2023-08-21 14:15:52 -07:00
FieldVisitorDump.h Add field CustomType 2023-02-03 17:07:02 +01:00
FieldVisitorHash.cpp Fix build 2023-02-04 13:49:32 +01:00
FieldVisitorHash.h Add field CustomType 2023-02-03 17:07:02 +01:00
FieldVisitors.h Minor changes 2021-06-14 07:13:35 +03:00
FieldVisitorsAccurateComparison.h Allow accurate comparison of Big Int with other integers 2023-02-08 07:56:00 +01:00
FieldVisitorSum.cpp Fix build 2023-02-04 13:49:32 +01:00
FieldVisitorSum.h Add field CustomType 2023-02-03 17:07:02 +01:00
FieldVisitorToString.cpp Map field to string fix 2023-02-26 13:38:45 +01:00
FieldVisitorToString.h Add field CustomType 2023-02-03 17:07:02 +01:00
FieldVisitorWriteBinary.cpp Fix build 2023-02-04 13:49:32 +01:00
FieldVisitorWriteBinary.h Add field CustomType 2023-02-03 17:07:02 +01:00
FileChecker.cpp fix sizes.log writes 2023-05-30 12:26:20 +02:00
FileChecker.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
FileRenamer.cpp Add placeholder for rull filename in rename_files_after_processing setting 2023-06-29 13:35:27 +00:00
FileRenamer.h Add placeholder for rull filename in rename_files_after_processing setting 2023-06-29 13:35:27 +00:00
filesystemHelpers.cpp check if a symlink exists more carefully 2023-03-08 00:04:55 +01:00
filesystemHelpers.h check if a symlink exists more carefully 2023-03-08 00:04:55 +01:00
FileUpdatesTracker.h Fix clang-tidy warnings in Common folder 2022-03-14 18:17:35 +00:00
format.h Fix msan issue in randomStringUTF8(<uneven number>) 2023-05-10 17:49:23 +00:00
formatIPv6.cpp use std::lerp, constexpr hex.h 2023-03-07 22:50:17 +00:00
formatIPv6.h use std::lerp, constexpr hex.h 2023-03-07 22:50:17 +00:00
formatReadable.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
formatReadable.h Preparation for libcxx(abi), llvm, clang-tidy 16 2023-03-19 17:25:41 +00:00
FrequencyHolder.cpp Attempt to fix LTO 2023-07-24 00:03:40 +02:00
FrequencyHolder.h Fix fasttest 2023-07-23 17:59:49 +02:00
FST.cpp Ditch tons of garbage 2023-08-09 02:19:02 +02:00
FST.h Various cosmetic cleanups 2023-01-20 10:45:35 +00:00
FunctionDocumentation.cpp Introduce more fields for in-source function documentation 2023-05-05 21:30:21 +00:00
FunctionDocumentation.h Introduce more fields for in-source function documentation 2023-05-05 21:30:21 +00:00
futex.h review fixes + split into files 2023-01-09 14:58:44 +00:00
getCurrentProcessFDCount.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
getCurrentProcessFDCount.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
getExecutablePath.cpp
getExecutablePath.h
getHashOfLoadedBinary.cpp Implement endianness-independent SipHash and MergeTree checksum serialization 2023-07-19 10:01:55 -07:00
getHashOfLoadedBinary.h Fix style 2021-01-07 06:40:24 +03:00
getMappedArea.cpp use std::lerp, constexpr hex.h 2023-03-07 22:50:17 +00:00
getMappedArea.h Check for #pragma once in headers 2020-10-10 21:37:02 +03:00
getMaxFileDescriptorCount.cpp More consistent use of platform macros 2022-06-10 10:22:31 +02:00
getMaxFileDescriptorCount.h code style change 2021-11-12 20:48:42 +08:00
getMultipleKeysFromConfig.cpp
getMultipleKeysFromConfig.h
getNumberOfPhysicalCPUCores.cpp Add cgroupsv2 for getCGroupLimitedCPUCores 2023-06-28 22:19:44 +02:00
getNumberOfPhysicalCPUCores.h
GetPriorityForLoadBalancing.cpp Unify priorities for connections 2023-06-07 16:25:52 +00:00
GetPriorityForLoadBalancing.h Unify priorities for connections 2023-06-07 16:25:52 +00:00
getRandomASCIIString.cpp Remove some trash 2022-08-21 20:46:33 +02:00
getRandomASCIIString.h Remove some trash 2022-08-21 20:46:33 +02:00
hasLinuxCapability.cpp More consistent use of platform macros 2022-06-10 10:22:31 +02:00
hasLinuxCapability.h More consistent use of platform macros 2022-06-10 10:22:31 +02:00
HTTPHeaderFilter.cpp Update src/Common/HTTPHeaderFilter.cpp 2023-08-08 17:13:43 +10:00
HTTPHeaderFilter.h Add HTTP header filtering 2023-06-15 13:49:49 +00:00
HyperLogLogBiasEstimator.h
HyperLogLogCounter.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
HyperLogLogWithSmallSetOptimization.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
ICachePolicy.h Cosmetics 2023-08-21 14:08:44 +00:00
ICachePolicyUserQuota.h Query Cache: Implement per-user quotas 2023-04-23 16:13:51 +00:00
IFactoryWithAliases.h fix 2023-07-16 17:13:40 +00:00
Increment.h Fix clang-tidy warnings in Common folder 2022-03-14 18:17:35 +00:00
InterruptListener.h More consistent use of platform macros 2022-06-10 10:22:31 +02:00
IntervalKind.cpp Implement KQL-style formatting for Interval 2023-07-10 13:51:49 -04:00
IntervalKind.h Implement KQL-style formatting for Interval 2023-07-10 13:51:49 -04:00
IntervalTree.h Use concepts to replace more std::enable_if_t 2023-08-02 07:50:25 +00:00
intExp.h Merge remote-tracking branch 'upstream/master' into build/shorten-64-to-32 2022-10-21 22:51:56 +02:00
IO.cpp Enable clang-tidy modernize-deprecated-headers & hicpp-deprecated-headers 2022-05-09 08:23:33 +02:00
IO.h Add writeRetry helper 2021-06-07 09:38:15 +03:00
IPv6ToBinary.cpp Use std::popcount, ::countl_zero, ::countr_zero functions 2022-07-31 15:16:51 +00:00
IPv6ToBinary.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
isLocalAddress.cpp Fix some grammar mistakes in documentation, code and tests 2023-05-04 13:35:18 -03:00
isLocalAddress.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
isValidUTF8.cpp Move isValidUTF8Naive from Functions to Common 2021-08-23 09:22:15 +03:00
isValidUTF8.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
JSONBuilder.cpp Use JSONBuilder for explain json result. 2021-04-14 17:07:56 +03:00
JSONBuilder.h Remove PVS-Studio 2023-02-19 23:30:05 +01:00
KnownObjectNames.cpp Fix style. 2022-11-16 01:35:11 +01:00
KnownObjectNames.h Move maskSensitiveInfoInQueryForLogging() to src/Parsers/ 2022-11-14 18:55:19 +01:00
likePatternToRegexp.cpp Move likePatternToRegexp from Functions/ to Common/ 2023-02-27 16:41:15 +00:00
likePatternToRegexp.h Move likePatternToRegexp from Functions/ to Common/ 2023-02-27 16:41:15 +00:00
LocalDate.h cosmetic changes 2023-06-08 16:05:14 +02:00
LocalDateTime.h Fix call to wrong overload on Darwin 2022-12-21 09:00:44 +00:00
LockMemoryExceptionInThread.cpp Move LockMemoryExceptionInThread and MemoryTrackerBlockerInThread 2022-01-10 22:39:10 +03:00
LockMemoryExceptionInThread.h fix build on USE_DEBUG_HELPERS OFF 2022-01-24 14:29:38 +08:00
logger_useful.h Improve logging macros (#52519) 2023-07-26 23:38:14 +03:00
LoggingFormatStringHelpers.cpp initialize SeriesRecords for LogSeriesLimiter lazy 2023-07-06 19:49:22 +02:00
LoggingFormatStringHelpers.h Continue on garbage removal 2023-08-09 02:58:12 +02:00
LRUCachePolicy.h Cosmetics 2023-08-21 14:08:44 +00:00
LRUResourceCache.h Change class LRUCache to class CachBase. Check running CacheBase with default pcahce policy SLRU 2022-08-07 19:59:30 +00:00
Macros.cpp Add a test 2023-04-09 03:25:38 +02:00
Macros.h Fix clang-tidy warnings in Common folder 2022-03-14 18:17:35 +00:00
makeSocketAddress.cpp Move common code 2023-05-19 16:23:56 +02:00
makeSocketAddress.h Fix style check 2023-05-19 17:35:01 +02:00
malloc.cpp Clean up GCC warning pragmas 2023-04-11 18:21:08 +00:00
memcmpSmall.h AARCH64 Neon memequal wide 2023-08-20 12:45:18 +03:00
memcpySmall.h Remove cruft from build 2023-03-17 13:44:04 +00:00
memory.h Merge branch 'master' into revert-44629-revert_flamegraph 2023-06-27 17:26:25 +00:00
MemorySanitizer.h Fix clang-tidy warnings in Common folder 2022-03-14 18:17:35 +00:00
MemoryStatisticsOS.cpp Fix -Wzero-as-null-pointer-constant in MemoryStatisticsOS::get for FreeBSD 2022-09-10 21:38:35 +02:00
MemoryStatisticsOS.h Fix -Wshorten-64-to-32 on FreeBSD 2022-12-12 08:05:28 +01:00
MemoryTracker.cpp fix 2023-08-15 15:37:09 +02:00
MemoryTracker.h Fixing a test. 2023-08-03 09:35:45 +00:00
MemoryTrackerBlockerInThread.cpp Make only one possible public ctor in MemoryTrackerBlockerInThread 2022-07-26 19:03:26 +00:00
MemoryTrackerBlockerInThread.h Revert "Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2023-01-16 15:10:31 +01:00
MemoryTrackerSwitcher.h Fix using of pools from the main thread 2023-07-09 14:21:27 +02:00
MultiVersion.h Add TODO comment to MultiVersion.h 2023-02-06 11:04:58 +00:00
NamePrompter.cpp Added compound types typo corrections 2022-11-10 19:21:51 +01:00
NamePrompter.h less exceptions with runtime format string 2023-08-14 21:45:59 +02:00
NaNUtils.h Upd upstream 2021-05-28 00:21:02 +03:00
NetException.h Use concepts to replace more std::enable_if_t 2023-08-02 07:50:25 +00:00
NetlinkMetricsProvider.cpp Rename TaskStatsInfoGetter into NetlinkMetricsProvider 2023-07-21 06:48:18 +02:00
NetlinkMetricsProvider.h Rename TaskStatsInfoGetter into NetlinkMetricsProvider 2023-07-21 06:48:18 +02:00
new_delete.cpp Merge branch 'master' into revert-44629-revert_flamegraph 2023-06-27 17:26:25 +00:00
noexcept_scope.h Fix NOEXCEPT_SCOPE (before it calls std::terminate and looses the exception) 2022-07-14 17:16:18 +03:00
ObjectPool.h Fix Bug 37114 - ilike on FixedString(N) columns produces wrong results 2022-05-11 14:30:21 +02:00
OpenSSLHelpers.cpp Clean up GCC warning pragmas 2023-04-11 18:21:08 +00:00
OpenSSLHelpers.h Generate config.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
OpenTelemetryTraceContext.cpp Addressing feedback. 2023-08-18 13:50:31 -07:00
OpenTelemetryTraceContext.h Some improvements about names of span logs (#47667) 2023-03-29 16:28:36 +02:00
OptimizedRegularExpression.cpp Update src/Common/OptimizedRegularExpression.cpp 2023-08-01 13:43:28 -04:00
OptimizedRegularExpression.h Follow-up to re2 update 2023-06-02 (#50949) 2023-07-03 08:28:25 +00:00
OvercommitTracker.cpp Also count waiting on global mutext 2022-12-14 18:05:07 +00:00
OvercommitTracker.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
parseAddress.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
parseAddress.h Remove Arcadia 2022-04-19 17:44:27 +02:00
parseGlobs.cpp Follow-up to re2 update 2023-06-02 (#50949) 2023-07-03 08:28:25 +00:00
parseGlobs.h
parseRemoteDescription.cpp Check for punctuation 2023-07-25 06:10:04 +02:00
parseRemoteDescription.h Check for punctuation 2023-07-25 06:10:04 +02:00
PipeFDs.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
PipeFDs.h Fix response pipe read 2020-11-27 13:12:11 +03:00
PODArray_fwd.h Adapt internal data structures to 512-bit era (#42564) 2022-10-25 13:56:28 +02:00
PODArray.cpp Partially reimplement Parquet encoder to make it faster and parallelizable 2023-07-25 10:16:28 +00:00
PODArray.h Partially reimplement Parquet encoder to make it faster and parallelizable 2023-07-25 10:16:28 +00:00
PoolBase.h use connection pool 2023-06-14 12:51:02 +02:00
PoolWithFailoverBase.h Unify priorities for connections 2023-06-07 16:25:52 +00:00
Priority.h Unify priorities: lower value means higher priority (#50205) 2023-05-26 15:55:30 +02:00
ProcfsMetricsProvider.cpp Check return value of ::close() 2023-02-07 11:28:22 +01:00
ProcfsMetricsProvider.h Merge pull request #37969 from ClickHouse/consistent-macro-usage 2022-06-10 14:10:01 +02:00
ProfileEvents.cpp Merge pull request #52309 from rschu1ze/qc-event-descr 2023-07-25 13:54:06 +02:00
ProfileEvents.h Add ProfileEvents for log messages 2023-04-22 14:55:25 +02:00
ProfileEventsScope.cpp Allow scope override in ThreadStatus::attachProfileCountersScope 2023-02-14 14:11:13 +00:00
ProfileEventsScope.h Allow scope override in ThreadStatus::attachProfileCountersScope 2023-02-14 14:11:13 +00:00
ProfilingScopedRWLock.h review fixes 2023-01-12 15:51:04 +00:00
ProgressIndication.cpp Added peak_memory_usage to final progress 2023-08-03 02:45:37 +00:00
ProgressIndication.h Remove spaces 2023-07-17 10:36:23 +00:00
QueryProfiler.cpp Force libunwind usage (removes gcc_eh support) 2023-07-08 20:55:50 +02:00
QueryProfiler.h Force libunwind usage (removes gcc_eh support) 2023-07-08 20:55:50 +02:00
quoteString.cpp MaterializedMySQL: Support unquoted utf-8 strings in DDL 2023-07-24 11:12:10 +02:00
quoteString.h MaterializedMySQL: Support unquoted utf-8 strings in DDL 2023-07-24 11:12:10 +02:00
RadixSort.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
randomSeed.cpp Implement endianness-independent SipHash and MergeTree checksum serialization 2023-07-19 10:01:55 -07:00
randomSeed.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
register_objects.cpp Automated function registration 2022-07-29 15:39:50 +08:00
register_objects.h Automated function registration 2022-07-29 15:39:50 +08:00
remapExecutable.cpp What happens if I remove these 139 lines of code? 2023-01-03 18:35:31 +00:00
remapExecutable.h Log size of remapped memory (remap_executable) 2021-11-04 00:19:00 +03:00
RemoteHostFilter.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
RemoteHostFilter.h Support for Clang Thread Safety Analysis (TSA) 2022-06-20 16:13:25 +02:00
RWLock.cpp Forbid insert select for the same StorageJoin 2023-03-09 12:28:44 +00:00
RWLock.h Fix some grammar mistakes in documentation, code and tests 2023-05-04 13:35:18 -03:00
safe_cast.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
scope_guard_safe.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
SensitiveDataMasker.cpp Follow-up to re2 update 2023-06-02 (#50949) 2023-07-03 08:28:25 +00:00
SensitiveDataMasker.h Fix style. 2022-11-16 01:35:11 +01:00
setThreadName.cpp do not fail if prctl is not allowed 2023-08-07 17:03:48 +02:00
setThreadName.h Remove thread_local std::string 2021-11-14 02:43:17 +03:00
SettingConstraintWritability.h review fixes 2022-09-15 11:34:14 +00:00
SettingsChanges.cpp review suggestions 2023-02-22 17:22:13 +00:00
SettingsChanges.h comments fix 2023-02-24 19:19:51 +00:00
SettingSource.h Implemented max sessions for user 2023-07-30 22:09:03 +00:00
SharedBlockRowRef.h Fix clang-tidy warnings in Common folder 2022-03-14 18:17:35 +00:00
SharedMutex.cpp fix try_shared_lock() in SharedMutex and CancelableSharedMutex 2023-01-24 14:36:07 +00:00
SharedMutex.h fix special builds 2023-01-12 01:30:42 +00:00
ShellCommand.cpp Fix data race of shell command 2023-08-22 14:50:56 +08:00
ShellCommand.h Don't be kind with third-party code 2022-12-28 20:07:26 +01:00
ShellCommandSettings.cpp Refactor 2023-08-18 15:38:46 +08:00
ShellCommandSettings.h Refactor 2023-08-18 15:38:46 +08:00
shuffle.h FIXUP: More comments about shuffle 2023-01-27 20:07:56 +00:00
SimpleActionBlocker.h
SimpleIncrement.h Rename "common" to "base" 2021-10-02 10:13:14 +03:00
SipHash.h Improve function naming 2023-07-31 06:48:50 -07:00
SLRUCachePolicy.h Cosmetics 2023-08-21 14:08:44 +00:00
SmallObjectPool.h Fix clang-tidy warnings in Common folder 2022-03-14 18:17:35 +00:00
SpaceSaving.h Ditch tons of garbage 2023-08-09 02:19:02 +02:00
StackTrace.cpp Cleanup SymbolIndex after reload got removed 2023-07-09 09:25:11 +02:00
StackTrace.h added to fatal errors handler, added comments 2023-06-24 17:24:54 +00:00
StatusFile.cpp fix multipart requests 2023-02-22 17:54:35 +01:00
StatusFile.h Normalize "pid" file handling #3501 2020-07-04 16:54:24 +03:00
StatusInfo.cpp StatusInfo will be deprecated 2023-07-06 11:48:21 +08:00
StatusInfo.h Use StrongTypedef for StatusInfo 2023-04-01 16:01:33 +02:00
Stopwatch.h Use CLOCK_MONOTONIC_RAW over CLOCK_MONOTONIC on Linux (fixes non monotonic clock) 2023-05-12 10:59:53 +02:00
StringSearcher.h Remove bad code and fix a bug 2023-06-28 10:41:39 +02:00
StudentTTest.cpp Ditch tons of garbage 2023-08-09 02:19:02 +02:00
StudentTTest.h Fix half of trash 2022-09-10 04:08:16 +02:00
SymbolIndex.cpp Merge branch 'incbin' into no-export-dynamic 2023-07-23 21:34:12 +02:00
SymbolIndex.h Use incbin for resources, part 2 2023-07-23 06:11:03 +02:00
SystemLogBase.cpp style corrections 2023-07-28 07:32:53 +00:00
SystemLogBase.h Simplification 2023-08-11 03:06:07 +02:00
TargetSpecific.cpp ColumnVector: re-enable AVX512_VBMI/AVX512_VBMI2 optimized filter and index (#41765) 2022-10-24 23:11:46 +02:00
TargetSpecific.h Merge branch 'master' into Aggregate_Sum_AVX512 2023-02-19 04:03:45 +03:00
TerminalSize.cpp Use stderr instead of stdout 2021-05-05 15:52:21 +00:00
TerminalSize.h Fix clang-tidy warnings in Common folder 2022-03-14 18:17:35 +00:00
thread_local_rng.cpp
thread_local_rng.h
ThreadFuzzer.cpp Merge pull request #47659 from ClickHouse/fix_993 2023-03-18 14:46:43 +03:00
ThreadFuzzer.h fix intersecting parts, better fault injections 2023-03-16 21:28:07 +01:00
ThreadPool_fwd.h Use forward declaration of ThreadPool 2023-04-07 11:25:35 +02:00
ThreadPool.cpp Ditch tons of garbage 2023-08-09 02:19:02 +02:00
ThreadPool.h added setting 'enable_job_stack_trace', default is off 2023-06-28 01:39:06 +00:00
ThreadProfileEvents.cpp Rename TaskStatsInfoGetter into NetlinkMetricsProvider 2023-07-21 06:48:18 +02:00
ThreadProfileEvents.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
ThreadStatus.cpp Merge branch 'master' into more-checks-in-thread-status 2023-07-22 04:58:28 +03:00
ThreadStatus.h Remove maybe_unused 2023-07-07 11:41:01 +00:00
Throttler_fwd.h add max_remote_{read,write}_network_bandwidth_for_server settings 2022-07-11 14:59:39 +02:00
Throttler.cpp Fix {Local,Remote}ReadThrottlerSleepMicroseconds metric values 2023-05-17 12:12:39 +02:00
Throttler.h Fix {Local,Remote}ReadThrottlerSleepMicroseconds metric values 2023-05-17 12:12:39 +02:00
TimerDescriptor.cpp Allow to run in Linux without PRCTL support 2023-05-05 06:40:12 +02:00
TimerDescriptor.h clang-tidy check performance-noexcept-move-constructor fix 2022-03-02 18:15:27 +00:00
TLDListsHolder.cpp Apply some CTAD 2023-03-02 13:36:47 +00:00
TLDListsHolder.h Reduce the usage of Arena.h 2023-04-13 10:31:32 +02:00
TraceSender.cpp Revert "Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2023-01-16 15:10:31 +01:00
TraceSender.h Revert "Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2023-01-16 15:10:31 +01:00
TransactionID.cpp save versions of parts 2021-12-30 16:15:28 +03:00
TransactionID.h more introspection 2022-03-18 14:33:59 +01:00
TransformEndianness.hpp Eliminate duplicate include 2023-08-15 13:54:28 +00:00
TTLCachePolicy.h Cosmetics 2023-08-21 14:08:44 +00:00
typeid_cast.h remove try-catch from the impl of typeid_cast for refs 2023-06-04 16:22:58 +03:00
TypePromotion.h
UnicodeBar.cpp Ditch tons of garbage 2023-08-09 02:19:02 +02:00
UnicodeBar.h Check remaining space to avoid buffer overruns; some cleanups 2022-12-20 02:39:44 +01:00
UTF8Helpers.cpp Use std::popcount, ::countl_zero, ::countr_zero functions 2022-07-31 15:16:51 +00:00
UTF8Helpers.h AARCH64 Neon memequal wide 2023-08-20 12:45:18 +03:00
VariableContext.h Remove redundant enumerator 2021-10-12 13:46:32 +03:00
VersionNumber.cpp Rewrite VersionNumber in ClickHouse way 2023-03-01 11:07:31 +08:00
VersionNumber.h Ditch tons of garbage 2023-08-09 02:19:02 +02:00
Visitor.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
Volnitsky.h Remove bad code and fix a bug 2023-06-28 10:41:39 +02:00
waitForPid.cpp Use __powerpc64__ over __ppc64__ (clang 16 stops declaring __ppc64__) 2023-05-09 12:20:50 +02:00
waitForPid.h ShellCommand wait pid refactoring 2022-07-21 11:45:09 +02:00
WeakHash.cpp
WeakHash.h feat: Use non-default initial value for CRC32, a lot of perf 2022-06-19 16:41:03 +03:00
XMLUtils.cpp Followup fixes for XML helpers (#43845) 2022-12-01 13:36:40 +01:00
XMLUtils.h Followup fixes for XML helpers (#43845) 2022-12-01 13:36:40 +01:00