ClickHouse/src/Common
Sema Checherinda 4dd86a406a
Merge pull request #48543 from azat/mv-uniq-thread-group
Use one ThreadGroup while pushing to materialized views (and some refactoring for ThreadGroup)
2023-04-11 11:47:46 +02:00
..
benchmarks Add google benchmark to contrib (#43779) 2022-12-08 13:38:08 +01:00
Config Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
examples ThreadPool metrics introspection 2023-03-29 10:46:59 +02:00
HashTable Better error messages 2023-03-19 05:34:44 +01:00
JSONParsers Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
mysqlxx Use std::string::starts_with instead of a roll your own variant 2023-04-06 11:57:44 -07:00
NamedCollections Fix tests 2023-02-27 17:42:04 +01:00
StringUtils Preparation for libcxx(abi), llvm, clang-tidy 16 2023-03-19 17:25:41 +00:00
tests Fix ThreadPool usage in gtest_thread_pool_limit 2023-04-01 16:00:03 +02:00
ZooKeeper Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
ActionBlocker.h
ActionLock.cpp
ActionLock.h
AlignedBuffer.cpp
AlignedBuffer.h
Allocator_fwd.h
Allocator.cpp
Allocator.h add new metric to record allocations times and bytes using mmap 2023-02-06 17:50:45 +08:00
AllocatorWithMemoryTracking.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
Arena.h Fix ubsan in AggregateFunctionMinMaxAny::read with high sizes 2022-11-15 15:40:06 +01:00
ArenaAllocator.h
ArenaUtils.h
ArenaWithFreeLists.h
ArrayCache.h Fix clang-tidy warnings (from clang-15) 2022-09-10 21:38:35 +02:00
assert_cast.h forbid old ctor of Exception 2023-01-23 22:18:05 +01:00
AsynchronousMetrics.cpp Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
AsynchronousMetrics.h Added two metrics about memory usage in cgroup to asynchronous metrics (#45301) 2023-01-25 20:32:17 +01:00
atomicRename.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
atomicRename.h
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 Merge branch 'master' into pr/BigRedEye/38191 2022-09-30 09:40:47 +00:00
BridgeProtocolVersion.h Add simple versioning to the *-bridge-to-server protocol 2022-08-08 19:40:37 +00:00
CacheBase.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02: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 Merge branch 'master' into fix_cares_crash 2023-01-30 12:05:56 -03:00
CaresPTRResolver.h add comments to the code 2023-01-26 13:54:12 -03:00
checkStackSize.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
checkStackSize.h
clearPasswordFromCommandLine.cpp
clearPasswordFromCommandLine.h
clickhouse_malloc.cpp Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
ClickHouseRevision.cpp Generate config_version.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
ClickHouseRevision.h
CMakeLists.txt Add google benchmark to contrib (#43779) 2022-12-08 13:38:08 +01: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.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
ConcurrentBoundedQueue.h [rev: 1] Fix review remarks 2023-03-17 13:56:05 +03:00
config_version.h.in Make comment consistent accross generated files 2022-09-28 08:11:09 +00:00
config.h.in Merge remote-tracking branch 'upstream/master' into ulid 2023-02-14 13:41:17 +00:00
CounterInFile.h Check return value of ::close() 2023-02-07 11:28:22 +01:00
COW.h
CpuId.h ColumnVector: re-enable AVX512_VBMI/AVX512_VBMI2 optimized filter and index (#41765) 2022-10-24 23:11:46 +02:00
createHardLink.cpp
createHardLink.h
CurrentMemoryTracker.cpp fix intersecting parts, better fault injections 2023-03-16 21:28:07 +01:00
CurrentMemoryTracker.h fix intersecting parts, better fault injections 2023-03-16 21:28:07 +01:00
CurrentMetrics.cpp Use StrongTypedef for CurrentMetrics to avoid possible incorrect usage 2023-04-01 16:01:33 +02:00
CurrentMetrics.h Use StrongTypedef for CurrentMetrics to avoid possible incorrect usage 2023-04-01 16:01:33 +02:00
CurrentThread.cpp Rename ThreadGroupStatus to ThreadGroup 2023-04-07 15:31:48 +02:00
CurrentThread.h Rename ThreadGroupStatus to ThreadGroup 2023-04-07 15:31:48 +02:00
DateLUT.cpp Apply some CTAD 2023-03-02 13:36:47 +00:00
DateLUT.h Remove PVS-Studio 2023-02-19 23:30:05 +01:00
DateLUTImpl.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
DateLUTImpl.h Various test, code and docs fixups 2023-01-15 13:47:34 +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
DNSResolver.cpp Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
DNSResolver.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
Documentation.h Add Documentation to FunctionFactory 2022-08-27 22:06:57 +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
Epoll.cpp Check return value of ::close() 2023-02-07 11:28:22 +01:00
Epoll.h Preparation for libcxx(abi), llvm, clang-tidy 16 2023-03-19 17:25:41 +00:00
ErrorCodes.cpp Allow skipping errors related to unknown enum values in row input formats 2023-03-29 00:31:53 +02:00
ErrorCodes.h
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 Try to make MergeTreeRestartingThread more reactive in case of expired sessions (#41092) 2022-09-23 14:40:04 +02:00
EventRateMeter.h typo 2022-11-17 16:20:21 +00:00
Exception.cpp Merge two overridden functions as one 2023-02-03 15:27:45 +08:00
Exception.h Add support for {server_uuid} macro 2023-04-09 03:04:26 +02:00
ExponentiallySmoothedCounter.h
ExternalLoaderStatus.h
ExternalModelInfo.h chore: restore SYSTEM RELOAD MODEL(S) and moniting view SYSTEM.MODELS 2022-09-12 19:33:02 +00:00
Fiber.h
FiberStack.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +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 Fix build 2023-02-04 13:49:32 +01: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
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 Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
FileChecker.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02: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
format.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03: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.h
FST.cpp Move method implementations (no other changes) 2023-01-20 10:57:16 +00:00
FST.h Various cosmetic cleanups 2023-01-20 10:45:35 +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 use std::lerp, constexpr hex.h 2023-03-07 22:50:17 +00:00
getHashOfLoadedBinary.h
getMappedArea.cpp use std::lerp, constexpr hex.h 2023-03-07 22:50:17 +00:00
getMappedArea.h
getMaxFileDescriptorCount.cpp
getMaxFileDescriptorCount.h
getMultipleKeysFromConfig.cpp
getMultipleKeysFromConfig.h
getNumberOfPhysicalCPUCores.cpp Update getNumberOfPhysicalCPUCores.cpp 2023-01-29 21:37:19 +01:00
getNumberOfPhysicalCPUCores.h
GetPriorityForLoadBalancing.cpp Fix stack-use-after-return in GetPriorityForLoadBalancing::getPriorityFunc() 2022-09-09 20:06:48 +02:00
GetPriorityForLoadBalancing.h
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
getResource.cpp
getResource.h
hasLinuxCapability.cpp
hasLinuxCapability.h
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 Introduce TTLCachePolicy 2023-03-14 09:45:20 +00:00
IFactoryWithAliases.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
Increment.h
InterruptListener.h
IntervalKind.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
IntervalKind.h Fix typos with new codespell 2022-09-02 08:54:48 +00:00
IntervalTree.h
intExp.h Merge remote-tracking branch 'upstream/master' into build/shorten-64-to-32 2022-10-21 22:51:56 +02:00
IO.cpp
IO.h
IPv6ToBinary.cpp Use std::popcount, ::countl_zero, ::countr_zero functions 2022-07-31 15:16:51 +00:00
IPv6ToBinary.h
isLocalAddress.cpp
isLocalAddress.h
isValidUTF8.cpp
isValidUTF8.h
JSONBuilder.cpp
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
LocalDateTime.h Fix call to wrong overload on Darwin 2022-12-21 09:00:44 +00:00
LockMemoryExceptionInThread.cpp
LockMemoryExceptionInThread.h
logger_useful.h work with comments on PR 2023-03-16 19:55:58 +01:00
LoggingFormatStringHelpers.cpp hide too noisy log messages, fix some tests 2023-03-14 00:23:36 +01:00
LoggingFormatStringHelpers.h hide too noisy log messages, fix some tests 2023-03-14 00:23:36 +01:00
LRUCachePolicy.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02: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
malloc.cpp Remove PVS-Studio 2023-02-19 23:30:05 +01:00
memcmpSmall.h Remove cruft from build 2023-03-17 13:44:04 +00:00
memcpySmall.h Remove cruft from build 2023-03-17 13:44:04 +00:00
memory.h fix compile 2023-02-08 18:06:36 +01:00
MemorySanitizer.h
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 deadlock due to debug tracking of memory allocations 2023-04-06 16:03:46 +02:00
MemoryTracker.h Fix deadlock due to debug tracking of memory allocations 2023-04-06 16:03:46 +02:00
MemoryTrackerBlockerInThread.cpp Make only one possible public ctor in MemoryTrackerBlockerInThread 2022-07-26 19:03:26 +00:00
MemoryTrackerBlockerInThread.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01: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 Added compound types typo corrections 2022-11-10 19:21:51 +01:00
NaNUtils.h
NetException.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
new_delete.cpp fix style 2023-02-08 22:16:28 +01:00
noexcept_scope.h
ObjectPool.h
OpenSSLHelpers.cpp Generate config.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
OpenSSLHelpers.h Generate config.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
OpenTelemetryTraceContext.cpp Some improvements about names of span logs (#47667) 2023-03-29 16:28:36 +02:00
OpenTelemetryTraceContext.h Some improvements about names of span logs (#47667) 2023-03-29 16:28:36 +02:00
OptimizedRegularExpression.cpp address comments 2023-03-22 17:50:19 +01:00
OptimizedRegularExpression.h address comments 2023-03-22 17:47:25 +01: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
parseGlobs.cpp Merge branch 'master' into 36316_Support_glob_for_recursive_directory_traversal 2022-10-24 18:34:19 +02:00
parseGlobs.h
parseRemoteDescription.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
parseRemoteDescription.h
PipeFDs.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
PipeFDs.h
PODArray_fwd.h Adapt internal data structures to 512-bit era (#42564) 2022-10-25 13:56:28 +02:00
PODArray.cpp Adapt internal data structures to 512-bit era (#42564) 2022-10-25 13:56:28 +02:00
PODArray.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
PoolBase.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
PoolWithFailoverBase.h Remove PVS-Studio 2023-02-19 23:30:05 +01:00
ProcfsMetricsProvider.cpp Check return value of ::close() 2023-02-07 11:28:22 +01:00
ProcfsMetricsProvider.h
ProfileEvents.cpp Add ability to throttle local IO on per-query/server basis 2023-04-05 09:39:15 +02:00
ProfileEvents.h Use StrongTypedef for ProfileEvents 2023-04-01 16:01:33 +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 remove counters for threads, fix negative counters 2023-03-15 22:22:22 +01:00
ProgressIndication.h remove counters for threads, fix negative counters 2023-03-15 22:22:22 +01:00
QueryProfiler.cpp Add sanity check of evtimer_del() in QueryProfiler 2023-02-06 20:13:05 +01:00
QueryProfiler.h Generate config.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
quoteString.cpp
quoteString.h
RadixSort.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
randomSeed.cpp
randomSeed.h
RangeGenerator.h
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
RemoteHostFilter.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
RemoteHostFilter.h
RWLock.cpp Forbid insert select for the same StorageJoin 2023-03-09 12:28:44 +00:00
RWLock.h Forbid insert select for the same StorageJoin 2023-03-09 12:28:44 +00: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 wipeSensitiveDataAndCutToLength take into accound suffix length 2023-03-20 15:54:19 +00:00
SensitiveDataMasker.h Fix style. 2022-11-16 01:35:11 +01:00
setThreadName.cpp Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
setThreadName.h
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
SharedBlockRowRef.h
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 Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
ShellCommand.h Don't be kind with third-party code 2022-12-28 20:07:26 +01:00
shuffle.h FIXUP: More comments about shuffle 2023-01-27 20:07:56 +00:00
SimpleActionBlocker.h
SimpleIncrement.h
SipHash.h Fix SipHash integer hashing and byte order issue in GenerateRandom for s390x 2023-03-14 11:54:17 -04:00
SLRUCachePolicy.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
SmallObjectPool.h
SpaceSaving.h Fix nullptr to memcpy 2023-04-07 08:32:01 +00:00
StackTrace.cpp Update StackTrace.cpp 2023-03-07 01:30:44 +03:00
StackTrace.h initial solution 2023-03-06 19:35:00 +03:00
StatusFile.cpp fix multipart requests 2023-02-22 17:54:35 +01:00
StatusFile.h
StatusInfo.cpp Use StrongTypedef for StatusInfo 2023-04-01 16:01:33 +02:00
StatusInfo.h Use StrongTypedef for StatusInfo 2023-04-01 16:01:33 +02:00
Stopwatch.h Resubmit prefetches 2023-02-08 21:26:24 +01:00
StringSearcher.h More cosmetics 2023-02-24 10:14:58 +00:00
StudentTTest.cpp
StudentTTest.h Fix half of trash 2022-09-10 04:08:16 +02:00
SymbolIndex.cpp use std::lerp, constexpr hex.h 2023-03-07 22:50:17 +00:00
SymbolIndex.h Make getResource() independent from the order of the sections 2022-10-24 07:10:45 +02:00
SystemLogBase.cpp Use forward declaration of ThreadPool 2023-04-07 11:25:35 +02:00
SystemLogBase.h Use forward declaration of ThreadPool 2023-04-07 11:25:35 +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
TaskStatsInfoGetter.cpp Check return value of ::close() 2023-02-07 11:28:22 +01:00
TaskStatsInfoGetter.h
TerminalSize.cpp
TerminalSize.h
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 Merge pull request #47880 from azat/threadpool-introspection 2023-03-30 01:27:31 +03:00
ThreadPool.h Use forward declaration of ThreadPool 2023-04-07 11:25:35 +02:00
ThreadProfileEvents.cpp Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
ThreadProfileEvents.h Remove superfluous includes of logger_userful.h from headers 2023-04-10 17:59:30 +02:00
ThreadStatus.cpp Merge pull request #48543 from azat/mv-uniq-thread-group 2023-04-11 11:47:46 +02:00
ThreadStatus.h Move ThreadGroupSwitcher to ThreadStatus.h (out from MergeTree code) 2023-04-07 15:32:08 +02:00
Throttler_fwd.h
Throttler.cpp forbid old ctor of Exception 2023-01-23 22:18:05 +01:00
Throttler.h add detailed profile events for throttling 2023-01-17 18:29:24 +00:00
TimerDescriptor.cpp Check return value of ::close() 2023-02-07 11:28:22 +01:00
TimerDescriptor.h
TLDListsHolder.cpp Apply some CTAD 2023-03-02 13:36:47 +00:00
TLDListsHolder.h Add support of !/* (exclamation/asterisk) in custom TLDs 2022-07-26 08:34:30 +03:00
TraceSender.cpp Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
TraceSender.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
TransactionID.cpp
TransactionID.h
TTLCachePolicy.h Introduce TTLCachePolicy 2023-03-14 09:45:20 +00:00
typeid_cast.h Incorporate more review feedback 2023-04-05 19:43:30 +00:00
TypePromotion.h
UnicodeBar.cpp Fixed unused value warning 2022-12-21 10:55:20 +01: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 Remove cruft from build 2023-03-17 13:44:04 +00:00
VariableContext.h
VersionNumber.cpp Rewrite VersionNumber in ClickHouse way 2023-03-01 11:07:31 +08:00
VersionNumber.h Rewrite VersionNumber in ClickHouse way 2023-03-01 11:07:31 +08:00
Visitor.h Better formatting for exception messages (#45449) 2023-01-24 00:13:58 +03:00
Volnitsky.h Merge branch 'master' into StringSearcher 2023-02-23 11:54:05 +01:00
waitForPid.cpp Merge branch 'master' into z-build-0120 2023-02-09 14:49:22 -05:00
waitForPid.h ShellCommand wait pid refactoring 2022-07-21 11:45:09 +02:00
WeakHash.cpp
WeakHash.h
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