ClickHouse/src/Common
Sergei Trifonov 2c766cf75f
Merge pull request #59507 from ClickHouse/alter-table-forget-partition
Add `FORGET PARTITION` query to remove old partition nodes from ZooKeeper
2024-02-23 12:55:08 +01:00
..
benchmarks Disambiguate crc32 from crc32c for s390x impl. 2023-10-31 11:21:37 -07:00
Config Updated implementation 2024-01-25 14:31:49 +03:00
examples Remove some code 2024-01-13 03:48:04 +01:00
HashTable Fix aggregation issue in mixed cluster of x86_64 and aarch64 2024-01-23 09:21:17 -08:00
JSONParsers update 2023-09-15 16:05:17 +08:00
mysqlxx Updated implementation 2024-01-25 14:31:49 +03:00
NamedCollections Updated implementation 2024-01-25 14:31:49 +03:00
Scheduler Revert "Support resource request canceling" 2024-02-21 20:19:00 +01:00
SSH Allow to build without libssl 2024-01-25 21:14:03 +00:00
StringUtils Implemented globs to select * from '<file>' 2023-08-31 04:20:44 +00:00
tests Merge pull request #59313 from ClickHouse/abstract-concurrency-control 2024-02-21 15:04:03 +01:00
ZooKeeper fix auxiliary zookeepers 2024-02-20 22:41:49 +01:00
ActionBlocker.h
ActionLock.cpp
ActionLock.h
AlignedBuffer.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
AlignedBuffer.h
AllocationTrace.h Update AllocationTrace.h 2023-08-01 17:14:49 +00:00
Allocator_fwd.h [Resubmit] Remove mmap/mremap/munmap from Allocator.h (#52792) 2023-09-14 13:11:12 +02:00
Allocator.cpp Updated implementation 2024-01-25 14:31:49 +03:00
Allocator.h Move Allocator code into module part 2023-12-27 15:42:08 +01:00
AllocatorWithMemoryTracking.h
Arena.h Move Allocator code into module part 2023-12-27 15:42:08 +01:00
ArenaAllocator.h Avoid excessive allocation in Arena 2023-11-22 12:13:47 +01:00
ArenaUtils.h
ArenaWithFreeLists.h Move Allocator code into module part 2023-12-27 15:42:08 +01:00
ArrayCache.h Remove workaround for old enough MacOSX 2023-12-27 15:42:08 +01:00
assert_cast.h Cosmetics 2023-06-28 18:35:27 +00:00
assertProcessUserMatchesDataOwner.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
assertProcessUserMatchesDataOwner.h Fixed tests 2023-06-20 11:42:22 +03:00
AsynchronousMetrics.cpp Updated implementation 2024-01-25 14:31:49 +03:00
AsynchronousMetrics.h Updated implementation 2024-01-25 14:31:49 +03:00
AsyncLoader.cpp fix deadlock in AsyncLoader::stop() 2024-01-28 15:47:17 +00:00
AsyncLoader.h fix deadlock in AsyncLoader::stop() 2024-01-28 15:47:17 +00:00
AsyncTaskExecutor.cpp Destroy fiber in case of exception in cancelBefore in AsyncTaskExecutor (#55516) 2023-10-11 21:04:43 -07:00
AsyncTaskExecutor.h Merge pull request #50034 from Avogar/fiber-local-var-2 2023-05-30 17:50:31 +02:00
AtomicLogger.h Fixed build 2024-01-28 13:55:44 +03:00
atomicRename.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
atomicRename.h
Base58.cpp
Base58.h
Base64.cpp
Base64.h
BinStringDecodeHelper.h
BitHelpers.h Add missing includes into BitHelpers.h 2023-12-27 17:06:17 +01:00
BridgeProtocolVersion.h
CacheBase.h Incorporate review feedback 2024-01-11 13:53:08 +00:00
CalendarTimeInterval.cpp Things 2023-12-28 17:56:05 +00:00
CalendarTimeInterval.h Things 2023-12-28 17:56:05 +00:00
callOnce.h Fixed code review issues 2023-10-02 13:53:17 +03:00
CancelableSharedMutex.cpp
CancelableSharedMutex.h
CancelToken.cpp
CancelToken.h
CaresPTRResolver.cpp Fix some typos 2023-10-15 15:43:02 +02: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 Revert "Check stack size in Parser" 2024-02-21 11:33:08 +01:00
checkStackSize.h
clearPasswordFromCommandLine.cpp
clearPasswordFromCommandLine.h
clickhouse_malloc.cpp
ClickHouseRevision.cpp Fix build 2023-11-13 10:09:23 +01:00
ClickHouseRevision.h
CMakeLists.txt Use incbin for resources, part 1 2023-07-23 06:11:03 +02:00
ColumnsHashing.h
ColumnsHashingImpl.h slightly faster and perf test 2023-12-16 03:35:59 +00:00
CombinedCardinalityEstimator.h
CompactArray.h
Concepts.h
ConcurrencyControl.cpp split ISlotControl from ConcurrencyControl 2024-01-28 20:26:55 +00:00
ConcurrencyControl.h split ISlotControl from ConcurrencyControl 2024-01-28 20:26:55 +00:00
ConcurrentBoundedQueue.h Check for punctuation 2023-07-25 06:10:04 +02:00
config_version.cpp.in Fix build 2023-11-13 10:09:23 +01:00
config_version.h Fix style 2023-11-13 12:23:55 +01:00
config.h.in Allow to build without libssl 2024-01-25 21:14:03 +00:00
CounterInFile.h Merge branch 'master' into better-parsing-exceptions 2023-12-29 18:07:32 +01:00
COW.h
CPUID.h Mini cleanup of CPUID.h 2024-02-19 19:33:14 +00:00
createHardLink.cpp Review error codes 2023-12-18 10:40:02 +01:00
createHardLink.h
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 Flush StorageBuffer into multiple threads if num_layers > 1 2024-02-18 13:15:24 +01:00
CurrentMetrics.h Remove some code 2024-01-13 03:48:04 +01:00
CurrentThread.cpp Merge branch 'master' into disks-and-io-sheduler 2023-08-30 11:18:49 +00:00
CurrentThread.h Merge branch 'master' into disks-and-io-sheduler 2023-08-30 11:18:49 +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 Continue #45070 2023-09-11 13:47:06 +00:00
DNSPTRResolver.h
DNSPTRResolverProvider.cpp
DNSPTRResolverProvider.h
DNSResolver.cpp Revert "Implement system.dns_cache table (#59856)" 2024-02-17 01:46:41 +01:00
DNSResolver.h Revert "Implement system.dns_cache table (#59856)" 2024-02-17 01:46:41 +01:00
Dwarf.cpp Insignificant changes 2024-02-18 10:47:18 +01:00
Dwarf.h Switch from DWARF 4 to 5 and see what happens (#56770) 2023-11-16 09:58:00 -08:00
ElapsedTimeProfileEventIncrement.h impl 2024-01-30 20:35:10 +01:00
Elf.cpp DWARF input format (#55450) 2023-10-16 17:00:07 -07:00
Elf.h DWARF input format (#55450) 2023-10-16 17:00:07 -07:00
EnvironmentProxyConfigurationResolver.cpp Updated implementation 2024-01-25 14:31:49 +03:00
EnvironmentProxyConfigurationResolver.h Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy (#55033) 2023-11-04 13:47:52 -04:00
Epoll.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
Epoll.h Remove unused includes 2024-02-01 15:47:13 +00:00
ErrorCodes.cpp Merge branch 'master' into alter-table-forget-partition 2024-02-20 13:56:50 +01:00
ErrorCodes.h
ErrorHandlers.h Updated implementation 2024-01-25 14:31:49 +03:00
escapeForFileName.cpp Fix build 2023-11-15 08:36:24 +00:00
escapeForFileName.h Fix build 2023-11-15 08:36:24 +00:00
escapeString.cpp Fixed code review issues 2023-10-25 21:41:26 +03:00
escapeString.h Fixed code review issues 2023-10-25 21:41:26 +03:00
EventCounter.h
EventFD.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
EventFD.h
EventNotifier.cpp
EventNotifier.h Ditch tons of garbage 2023-08-09 02:19:02 +02:00
EventRateMeter.h
Exception.cpp Added AtomicLogger 2024-01-28 13:55:44 +03:00
Exception.h Strict aliasing for Int8 2024-02-06 20:33:32 +01:00
ExponentiallySmoothedCounter.h
ExternalLoaderStatus.h
ExternalModelInfo.h
FailPoint.cpp Remove unnecessary include 2024-02-14 13:17:55 +00:00
FailPoint.h Keep header the same as before 2024-02-14 13:19:34 +00:00
Fiber.h Revert "Check stack size in Parser" 2024-02-21 11:33:08 +01:00
FiberStack.h Move Allocator code into module part 2023-12-27 15:42:08 +01:00
FieldVisitorConvertToNumber.h Better code 2024-02-17 09:44:10 +01:00
FieldVisitorDump.cpp Parquet filter pushdown 2023-08-21 14:15:52 -07:00
FieldVisitorDump.h
FieldVisitorHash.cpp
FieldVisitorHash.h
FieldVisitors.h
FieldVisitorsAccurateComparison.h
FieldVisitorSum.cpp
FieldVisitorSum.h
FieldVisitorToString.cpp Fix parallel replicas in presense of a scalar subquery with a big integer value 2023-12-21 11:42:04 +01:00
FieldVisitorToString.h
FieldVisitorWriteBinary.cpp
FieldVisitorWriteBinary.h
FileChecker.cpp Updated implementation 2024-01-25 14:31:49 +03:00
FileChecker.h Updated implementation 2024-01-25 14:31:49 +03:00
FileRenamer.cpp Some fixups 2024-01-07 22:28:08 +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 Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
filesystemHelpers.h
FileUpdatesTracker.h
findExtreme.cpp Linter 2024-01-03 10:54:42 +00:00
findExtreme.h Move findNumeric to .cpp 2023-12-29 17:22:06 +01:00
format.h fix: fix format error 2023-12-06 14:04:44 +00:00
formatIPv6.cpp
formatIPv6.h Miscellaneous 2023-11-13 09:06:18 +01:00
formatReadable.cpp
formatReadable.h
FrequencyHolder.cpp Updated implementation 2024-01-25 14:31:49 +03: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 Speed up inverted index building using flat_hash_map 2023-10-02 15:20:35 -07:00
FunctionDocumentation.cpp
FunctionDocumentation.h Support clang-18 (Wmissing-field-initializers) 2023-08-23 15:53:45 +02:00
futex.h
getCurrentProcessFDCount.cpp Re-enable clang-tidy checks 2023-09-26 09:34:12 +00:00
getCurrentProcessFDCount.h
getExecutablePath.cpp
getExecutablePath.h
getHashOfLoadedBinary.cpp Implement endianness-independent SipHash and MergeTree checksum serialization 2023-07-19 10:01:55 -07:00
getHashOfLoadedBinary.h
getMappedArea.cpp
getMappedArea.h
getMaxFileDescriptorCount.cpp Update getMaxFileDescriptorCount.cpp 2024-01-19 20:07:38 +03:00
getMaxFileDescriptorCount.h Call getMaxFileDescriptorCount once 2024-01-19 08:19:20 +00:00
getMultipleKeysFromConfig.cpp
getMultipleKeysFromConfig.h
getNumberOfPhysicalCPUCores.cpp Cosmetics 2024-02-01 12:14:03 +00:00
getNumberOfPhysicalCPUCores.h
GetPriorityForLoadBalancing.cpp Revert "Revert flaky" 2024-01-19 13:51:30 +01:00
GetPriorityForLoadBalancing.h Revert "Revert flaky" 2024-01-19 13:51:30 +01:00
getRandomASCIIString.cpp
getRandomASCIIString.h
hasLinuxCapability.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
hasLinuxCapability.h
HTTPHeaderFilter.cpp Some fixups 2024-01-07 22:28:08 +00:00
HTTPHeaderFilter.h Add HTTP header filtering 2023-06-15 13:49:49 +00:00
HyperLogLogBiasEstimator.h
HyperLogLogCounter.h Remove useless header files 2023-11-06 03:49:55 +01:00
HyperLogLogWithSmallSetOptimization.h
ICachePolicy.h Incorporate review feedback 2024-01-11 13:53:08 +00:00
ICachePolicyUserQuota.h QueryCache: Fix odd bugs with user quota 2024-01-12 14:27:37 +00:00
IFactoryWithAliases.h Refactor IHints 2023-09-10 03:48:12 +00:00
Increment.h
InterruptListener.h Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
IntervalKind.cpp Implement KQL-style formatting for Interval 2023-07-10 13:51:49 -04:00
IntervalKind.h refreshable materialized views 2023-12-28 17:56:04 +00:00
IntervalTree.h Mirror change 2023-09-04 15:54:01 +00:00
intExp.h
IO.cpp
IO.h
iota.cpp Fix OSX build 2024-01-03 14:04:30 +01:00
iota.h Fix OSX build 2024-01-03 14:04:30 +01:00
IPv6ToBinary.cpp
IPv6ToBinary.h
isLocalAddress.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
isLocalAddress.h Add load balancing test_hostname_levenshtein_distance 2023-09-27 10:46:39 +08:00
ISlotControl.h Update src/Common/ISlotControl.h 2024-02-01 13:52:56 +01:00
isValidUTF8.cpp
isValidUTF8.h
Jemalloc.cpp Updated implementation 2024-01-25 14:31:49 +03:00
Jemalloc.h Add system commands and 4lw for jemalloc 2024-01-11 08:24:56 +00:00
JSONBuilder.cpp
JSONBuilder.h
KnownObjectNames.cpp
KnownObjectNames.h
levenshteinDistance.cpp More iota 2023-12-29 17:20:18 +01:00
levenshteinDistance.h Use levenshteinDistance for neareast hostname load balancer 2023-09-20 17:42:25 +08:00
likePatternToRegexp.cpp
likePatternToRegexp.h
LocalDate.h cosmetic changes 2023-06-08 16:05:14 +02:00
LocalDateTime.h
LockMemoryExceptionInThread.cpp Avoid memory exceptions in asio workers 2023-11-27 10:08:06 +00:00
LockMemoryExceptionInThread.h Avoid memory exceptions in asio workers 2023-11-27 10:08:06 +00:00
logger_useful.h Added AtomicLogger 2024-01-28 13:55:44 +03:00
Logger.cpp Updated implementation 2024-01-25 14:31:49 +03:00
Logger.h Revert "Revert "Poco Logger small refactoring"" 2024-02-09 21:39:35 +03:00
LoggingFormatStringHelpers.cpp Fix bad log message 2024-02-19 09:30:19 +01:00
LoggingFormatStringHelpers.h Updated implementation 2024-01-25 14:31:49 +03:00
LRUCachePolicy.h Some renamings for more consistency 2023-08-22 10:48:03 +00:00
LRUResourceCache.h Updated implementation 2024-01-25 14:31:49 +03:00
Macros.cpp Remove one unused implementation of Macros::expand() 2024-02-12 21:05:58 +01:00
Macros.h Remove one unused implementation of Macros::expand() 2024-02-12 21:05:58 +01:00
makeSocketAddress.cpp Updated implementation 2024-01-25 14:31:49 +03:00
makeSocketAddress.h Updated implementation 2024-01-25 14:31:49 +03:00
malloc.cpp
MatchGenerator.cpp remove debug logging 2024-01-08 15:58:47 +01:00
MatchGenerator.h remove debug logging 2024-01-08 15:58:47 +01:00
memcmpSmall.h Fix unpoison call 2024-02-09 11:08:54 +01:00
memcpySmall.h Enable MSAN in mem*Overflow15 functions 2024-02-07 20:23:52 +01:00
memory.h Merge branch 'master' into revert-44629-revert_flamegraph 2023-06-27 17:26:25 +00:00
MemorySanitizer.h Fix msan unpoison 2024-02-09 17:36:44 +01:00
MemoryStatisticsOS.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
MemoryStatisticsOS.h
MemoryTracker.cpp Updated implementation 2024-01-25 14:31:49 +03:00
MemoryTracker.h Fix wrong attribution of untracked memory to a user/query (#56089) 2023-11-02 17:14:15 +01:00
MemoryTrackerBlockerInThread.cpp
MemoryTrackerBlockerInThread.h
MemoryTrackerSwitcher.h Fix using of pools from the main thread 2023-07-09 14:21:27 +02:00
MortonUtils.h More comments 2023-10-15 06:15:59 +02:00
MultiVersion.h MultiVersion use mutex 2024-02-05 12:52:18 +03:00
NamePrompter.cpp
NamePrompter.h Do not include PODArray.h into NamePrompter.h 2023-12-27 15:42:08 +01:00
NaNUtils.h
NetException.h Use concepts to replace more std::enable_if_t 2023-08-02 07:50:25 +00:00
NetlinkMetricsProvider.cpp Updated implementation 2024-01-25 14:31:49 +03: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
ObjectPool.h
ObjectStorageKey.cpp object storage key template 2024-01-05 13:42:30 +00:00
ObjectStorageKey.h review notes 2023-11-03 22:43:40 +01:00
ObjectStorageKeyGenerator.cpp remove debug logging 2024-01-08 15:58:47 +01:00
ObjectStorageKeyGenerator.h object storage key template 2024-01-05 13:42:30 +00:00
OpenSSLHelpers.cpp
OpenSSLHelpers.h
OpenTelemetryTraceContext.cpp Move Allocator code into module part 2023-12-27 15:42:08 +01:00
OpenTelemetryTraceContext.h
OptimizedRegularExpression.cpp Updated implementation 2024-01-25 14:31:49 +03:00
OptimizedRegularExpression.h Some fixups 2024-01-07 22:28:08 +00:00
OvercommitTracker.cpp
OvercommitTracker.h
parseAddress.cpp
parseAddress.h
parseGlobs.cpp Some fixups 2024-01-07 22:28:08 +00:00
parseGlobs.h Update after review 2023-11-15 16:37:24 +01:00
parseRemoteDescription.cpp Updated implementation 2024-01-25 14:31:49 +03:00
parseRemoteDescription.h Review fixes 2023-12-12 05:48:09 +01:00
PipeFDs.cpp Updated implementation 2024-01-25 14:31:49 +03:00
PipeFDs.h
PODArray_fwd.h
PODArray.cpp Move some code from PODArray into implementation part 2023-12-27 17:06:17 +01:00
PODArray.h lower memory usage 2024-01-27 16:40:11 +00:00
PoolBase.h Updated implementation 2024-01-25 14:31:49 +03:00
PoolId.h comment 2023-11-07 10:24:56 +00:00
PoolWithFailoverBase.h Merge pull request #60077 from ClickHouse/cleanup-connection-pool-priority 2024-02-21 15:22:08 +01:00
Priority.h Unify priorities: lower value means higher priority (#50205) 2023-05-26 15:55:30 +02:00
ProcfsMetricsProvider.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
ProcfsMetricsProvider.h
ProfileEvents.cpp Merge branch 'master' into keeper-logs-cache 2024-02-19 10:01:31 +01:00
ProfileEvents.h Add system tables 2023-09-25 20:04:15 +02:00
ProfileEventsScope.cpp
ProfileEventsScope.h
ProfilingScopedRWLock.h
ProgressIndication.cpp Added peak_memory_usage to final progress 2023-08-03 02:45:37 +00:00
ProgressIndication.h Review #51946 and partially revert it 2023-10-08 15:17:41 +02:00
ProxyConfiguration.h Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy (#55033) 2023-11-04 13:47:52 -04:00
ProxyConfigurationResolver.h Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy (#55033) 2023-11-04 13:47:52 -04:00
ProxyConfigurationResolverProvider.cpp Updated implementation 2024-01-25 14:31:49 +03:00
ProxyConfigurationResolverProvider.h move mistaken include 2024-01-13 15:33:25 +03:00
ProxyListConfigurationResolver.cpp Updated implementation 2024-01-25 14:31:49 +03:00
ProxyListConfigurationResolver.h move mistaken include 2024-01-13 15:33:25 +03:00
QueryProfiler.cpp Updated implementation 2024-01-25 14:31:49 +03:00
QueryProfiler.h Updated implementation 2024-01-25 14:31:49 +03: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 Fixed code review issues 2024-02-13 15:41:17 +03:00
randomNumber.h MaterializedMySQL: Introduce MySQL Binlog Client 2024-01-03 15:26:09 +01:00
randomSeed.cpp Remove some code 2024-01-13 03:48:04 +01:00
randomSeed.h Remove some code 2024-01-13 03:48:04 +01:00
re2.h Fix style 2024-01-08 08:50:34 +00:00
register_objects.cpp
register_objects.h
remapExecutable.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
remapExecutable.h
RemoteHostFilter.cpp Some fixups 2024-01-07 22:28:08 +00:00
RemoteHostFilter.h
RemoteProxyConfigurationResolver.cpp Updated implementation 2024-01-25 14:31:49 +03:00
RemoteProxyConfigurationResolver.h Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy (#55033) 2023-11-04 13:47:52 -04:00
RWLock.cpp Fixed condition and add more chasserts for consistency checks. 2023-12-11 00:56:51 +01:00
RWLock.h Fix RWLock inconsistency after write lock timeout. 2023-12-11 00:56:06 +01:00
safe_cast.h
scope_guard_safe.h
SensitiveDataMasker.cpp Revert "Check stack size in Parser" 2024-02-21 11:33:08 +01:00
SensitiveDataMasker.h SensitiveDataMasker: replace shared_ptr with MultiVersion 2024-01-17 08:10:50 +02:00
setThreadName.cpp Allow setThreadName() to truncate thread name instead of throw an error 2023-12-28 15:32:39 +01:00
setThreadName.h Allow setThreadName() to truncate thread name instead of throw an error 2023-12-28 15:32:39 +01:00
SettingConstraintWritability.h
SettingsChanges.cpp
SettingsChanges.h
SettingSource.h Implemented max sessions for user 2023-07-30 22:09:03 +00:00
SharedLockGuard.h Convert unnecessary std::scoped_lock to std::lock_guard 2023-10-25 09:26:16 +00:00
SharedMutex.cpp
SharedMutex.h
SharedMutexHelper.h Fixed code review issues 2023-10-24 19:39:25 +03:00
ShellCommand.cpp Updated implementation 2024-01-25 14:31:49 +03:00
ShellCommand.h Updated implementation 2024-01-25 14:31:49 +03: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
SimpleIncrement.h
SipHash.h Revert "Check stack size in Parser" 2024-02-21 11:33:08 +01:00
SLRUCachePolicy.h Some renamings for more consistency 2023-08-22 10:48:03 +00:00
SpaceSaving.h Fix crash in topK when merging empty states 2024-02-05 20:52:54 +01:00
StackTrace.cpp Revert "Check stack size in Parser" 2024-02-21 11:33:08 +01:00
StackTrace.h Refactor stacktrace symbolizer to avoid copy-paste 2024-01-11 15:17:51 +03:00
StatusFile.cpp Updated implementation 2024-01-25 14:31:49 +03:00
StatusFile.h
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
SymbolIndex.cpp Minor cleanup of msan usage 2024-01-25 15:40:11 +00:00
SymbolIndex.h Use incbin for resources, part 2 2023-07-23 06:11:03 +02:00
SystemLogBase.cpp Updated implementation 2024-01-25 14:31:49 +03:00
SystemLogBase.h Updated implementation 2024-01-25 14:31:49 +03:00
TargetSpecific.cpp Print CPU flags at startup 2024-02-16 13:06:57 +01:00
TargetSpecific.h Merge pull request #58800 from ZhiguoZh/20240115-combine-filter-bmi2 2024-01-19 16:50:04 +01:00
TerminalSize.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
TerminalSize.h
thread_local_rng.cpp
thread_local_rng.h
ThreadFuzzer.cpp Review error codes 2023-12-18 10:40:02 +01:00
ThreadFuzzer.h
ThreadPool_fwd.h
ThreadPool.cpp Move some code of ThreadPool into module part 2023-12-27 17:06:17 +01:00
ThreadPool.h Move some code of ThreadPool into module part 2023-12-27 17:06:17 +01:00
threadPoolCallbackRunner.h Move threadPoolCallbackRunner to the "Common" folder. 2024-02-17 21:59:51 +01:00
ThreadProfileEvents.cpp Fix build 2024-02-16 15:26:08 +00:00
ThreadProfileEvents.h
ThreadStatus.cpp Updated implementation 2024-01-25 14:31:49 +03:00
ThreadStatus.h Updated implementation 2024-01-25 14:31:49 +03:00
Throttler_fwd.h
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 Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
TimerDescriptor.h Don't use default move assignment in TimerDescriptor 2023-09-19 11:45:53 +00:00
TLDListsHolder.cpp Updated implementation 2024-01-25 14:31:49 +03:00
TLDListsHolder.h
TraceSender.cpp
TraceSender.h
TransactionID.cpp
TransactionID.h
transformEndianness.h Remove useless header files 2023-11-06 03:49:55 +01:00
TTLCachePolicy.h Update comments 2024-01-15 10:41:47 +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
UTF8Helpers.cpp
UTF8Helpers.h AARCH64 Neon memequal wide 2023-08-20 12:45:18 +03:00
VariableContext.h
VersionNumber.cpp
VersionNumber.h Ditch tons of garbage 2023-08-09 02:19:02 +02:00
Visitor.h
Volnitsky.h Remove bad code and fix a bug 2023-06-28 10:41:39 +02:00
waitForPid.cpp
waitForPid.h
WeakHash.cpp
WeakHash.h
XMLUtils.cpp Fix Mac 2024-01-13 04:49:50 +01:00
XMLUtils.h