.. |
benchmarks
|
|
|
Config
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
examples
|
Fix compiling average example (suppress -Wframe-larger-than) (#49358)
|
2023-05-03 13:32:34 +02:00 |
HashTable
|
Merge pull request #49380 from azat/dict/hashed-memory
|
2023-05-21 15:46:41 +02:00 |
JSONParsers
|
|
|
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
|
Update gtest_async_loader.cpp
|
2023-05-29 15:50:06 +02:00 |
ZooKeeper
|
Add zookeeper name in endpoint id (#49780)
|
2023-05-25 12:50:14 +03:00 |
ActionBlocker.h
|
|
|
ActionLock.cpp
|
|
|
ActionLock.h
|
|
|
AlignedBuffer.cpp
|
|
|
AlignedBuffer.h
|
|
|
Allocator_fwd.h
|
|
|
Allocator.cpp
|
|
|
Allocator.h
|
|
|
AllocatorWithMemoryTracking.h
|
|
|
Arena.h
|
Arena used bytes
|
2023-04-24 10:46:23 +02:00 |
ArenaAllocator.h
|
|
|
ArenaUtils.h
|
|
|
ArenaWithFreeLists.h
|
Don't count unreserved bytes in Arenas as read_bytes
|
2023-04-13 12:43:24 +02:00 |
ArrayCache.h
|
|
|
assert_cast.h
|
|
|
assertProcessUserMatchesDataOwner.cpp
|
Move common code
|
2023-05-19 16:23:56 +02:00 |
assertProcessUserMatchesDataOwner.h
|
Move common code
|
2023-05-19 16:23:56 +02:00 |
AsynchronousMetrics.cpp
|
Implement a uniform way to query processor core IDs
|
2023-05-24 13:33:05 +00:00 |
AsynchronousMetrics.h
|
Fix build
|
2023-04-27 14:56:51 +03:00 |
AsyncLoader.cpp
|
Unify priorities: rework AsyncLoader
|
2023-05-26 16:46:59 +00:00 |
AsyncLoader.h
|
Unify priorities: rework AsyncLoader
|
2023-05-26 16:46:59 +00:00 |
AsyncTaskExecutor.cpp
|
Inherit context from parent fiber
|
2023-05-10 12:27:13 +00:00 |
AsyncTaskExecutor.h
|
Change fields destruction order in AsyncTaskExecutor
|
2023-05-23 16:14:24 +02:00 |
atomicRename.cpp
|
Use __powerpc64__ over __ppc64__ (clang 16 stops declaring __ppc64__)
|
2023-05-09 12:20:50 +02:00 |
atomicRename.h
|
|
|
Base58.cpp
|
|
|
Base58.h
|
|
|
Base64.cpp
|
|
|
Base64.h
|
|
|
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
|
|
|
CacheBase.h
|
Query Cache: Implement per-user quotas
|
2023-04-23 16:13:51 +00:00 |
CancelableSharedMutex.cpp
|
|
|
CancelableSharedMutex.h
|
|
|
CancelToken.cpp
|
Apply some CTAD
|
2023-03-02 13:36:47 +00:00 |
CancelToken.h
|
|
|
CaresPTRResolver.cpp
|
|
|
CaresPTRResolver.h
|
|
|
checkStackSize.cpp
|
|
|
checkStackSize.h
|
|
|
clearPasswordFromCommandLine.cpp
|
|
|
clearPasswordFromCommandLine.h
|
|
|
clickhouse_malloc.cpp
|
|
|
ClickHouseRevision.cpp
|
|
|
ClickHouseRevision.h
|
|
|
CMakeLists.txt
|
|
|
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
|
|
|
CompactArray.h
|
|
|
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
|
[rev: 1] Fix review remarks
|
2023-03-17 13:56:05 +03:00 |
config_version.h.in
|
|
|
config.h.in
|
Merge branch 'master' into hanfei/fiu
|
2023-05-09 01:14:30 +02:00 |
CounterInFile.h
|
|
|
COW.h
|
|
|
CpuId.h
|
|
|
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
|
Merge pull request #48787 from ClickHouse/background-memory-tracker
|
2023-05-09 07:58:36 +03:00 |
CurrentMetrics.h
|
Use StrongTypedef for CurrentMetrics to avoid possible incorrect usage
|
2023-04-01 16:01:33 +02:00 |
CurrentThread.cpp
|
Merge remote-tracking branch 'origin/master' into revert-47476-revert_46622
|
2023-04-21 16:40:04 +00:00 |
CurrentThread.h
|
Merge remote-tracking branch 'origin/master' into revert-47476-revert_46622
|
2023-04-21 16:40:04 +00: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
|
|
|
DateLUTImpl.h
|
Add DATE_SECONDS_PER_DAY macro definition to replace the numeric literal 86400
|
2023-05-22 09:23:23 +00:00 |
DNSPTRResolver.h
|
|
|
DNSPTRResolverProvider.cpp
|
|
|
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 |
Dwarf.cpp
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
Dwarf.h
|
|
|
ElapsedTimeProfileEventIncrement.h
|
|
|
Elf.cpp
|
|
|
Elf.h
|
|
|
Epoll.cpp
|
Improve async reading from socket
|
2023-03-15 12:18:08 +00:00 |
Epoll.h
|
Merge branch 'master' into non-blocking-connect
|
2023-03-20 13:23:55 +01:00 |
ErrorCodes.cpp
|
BACKUP now writes encrypted data for tables on encrypted disks.
|
2023-05-16 14:26:33 +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
|
|
|
EventFD.h
|
|
|
EventNotifier.cpp
|
|
|
EventNotifier.h
|
|
|
EventRateMeter.h
|
|
|
Exception.cpp
|
Fix clang-tidy build
|
2023-05-02 13:41:38 +00:00 |
Exception.h
|
Add support for {server_uuid} macro
|
2023-04-09 03:04:26 +02:00 |
ExponentiallySmoothedCounter.h
|
|
|
ExternalLoaderStatus.h
|
|
|
ExternalModelInfo.h
|
|
|
FailPoint.cpp
|
address comments
|
2023-05-10 13:56:17 +02:00 |
FailPoint.h
|
address comments
|
2023-05-10 13:56:17 +02:00 |
Fiber.h
|
|
|
FiberStack.h
|
|
|
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
|
|
|
FieldVisitorDump.h
|
|
|
FieldVisitorHash.cpp
|
|
|
FieldVisitorHash.h
|
|
|
FieldVisitors.h
|
|
|
FieldVisitorsAccurateComparison.h
|
|
|
FieldVisitorSum.cpp
|
Fix build
|
2023-02-04 13:49:32 +01:00 |
FieldVisitorSum.h
|
|
|
FieldVisitorToString.cpp
|
Map field to string fix
|
2023-02-26 13:38:45 +01:00 |
FieldVisitorToString.h
|
|
|
FieldVisitorWriteBinary.cpp
|
|
|
FieldVisitorWriteBinary.h
|
|
|
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
|
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
|
|
|
formatReadable.h
|
Preparation for libcxx(abi), llvm, clang-tidy 16
|
2023-03-19 17:25:41 +00:00 |
FrequencyHolder.h
|
|
|
FST.cpp
|
|
|
FST.h
|
|
|
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
|
|
|
getCurrentProcessFDCount.cpp
|
|
|
getCurrentProcessFDCount.h
|
|
|
getExecutablePath.cpp
|
dbms/ → src/
|
2020-04-03 18:14:31 +03:00 |
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
|
|
|
getNumberOfPhysicalCPUCores.h
|
|
|
GetPriorityForLoadBalancing.cpp
|
|
|
GetPriorityForLoadBalancing.h
|
|
|
getRandomASCIIString.cpp
|
|
|
getRandomASCIIString.h
|
|
|
getResource.cpp
|
|
|
getResource.h
|
|
|
hasLinuxCapability.cpp
|
|
|
hasLinuxCapability.h
|
|
|
HyperLogLogBiasEstimator.h
|
|
|
HyperLogLogCounter.h
|
|
|
HyperLogLogWithSmallSetOptimization.h
|
|
|
ICachePolicy.h
|
Query Cache: Implement per-user quotas
|
2023-04-23 16:13:51 +00:00 |
ICachePolicyUserQuota.h
|
Query Cache: Implement per-user quotas
|
2023-04-23 16:13:51 +00:00 |
IFactoryWithAliases.h
|
|
|
Increment.h
|
|
|
InterruptListener.h
|
|
|
IntervalKind.cpp
|
|
|
IntervalKind.h
|
|
|
IntervalTree.h
|
|
|
intExp.h
|
|
|
IO.cpp
|
|
|
IO.h
|
|
|
IPv6ToBinary.cpp
|
|
|
IPv6ToBinary.h
|
|
|
isLocalAddress.cpp
|
Fix some grammar mistakes in documentation, code and tests
|
2023-05-04 13:35:18 -03:00 |
isLocalAddress.h
|
|
|
isValidUTF8.cpp
|
|
|
isValidUTF8.h
|
|
|
JSONBuilder.cpp
|
|
|
JSONBuilder.h
|
Remove PVS-Studio
|
2023-02-19 23:30:05 +01:00 |
KnownObjectNames.cpp
|
|
|
KnownObjectNames.h
|
|
|
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
|
|
|
LockMemoryExceptionInThread.cpp
|
|
|
LockMemoryExceptionInThread.h
|
|
|
logger_useful.h
|
Remove extra semicolumns
|
2023-05-05 11:54:11 +03: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
|
Query Cache: Implement per-user quotas
|
2023-04-23 16:13:51 +00:00 |
LRUResourceCache.h
|
|
|
Macros.cpp
|
Add a test
|
2023-04-09 03:25:38 +02:00 |
Macros.h
|
|
|
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
|
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
|
Clean up GCC warning pragmas
|
2023-04-11 18:21:08 +00:00 |
MemorySanitizer.h
|
|
|
MemoryStatisticsOS.cpp
|
|
|
MemoryStatisticsOS.h
|
|
|
MemoryTracker.cpp
|
Do not log peak for background memory tracker
|
2023-04-14 16:49:14 +02:00 |
MemoryTracker.h
|
Do not log peak for background memory tracker
|
2023-04-14 16:49:14 +02:00 |
MemoryTrackerBlockerInThread.cpp
|
|
|
MemoryTrackerBlockerInThread.h
|
|
|
MultiVersion.h
|
|
|
NamePrompter.cpp
|
|
|
NamePrompter.h
|
|
|
NaNUtils.h
|
|
|
NetException.h
|
|
|
new_delete.cpp
|
|
|
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
|
|
|
OpenSSLHelpers.cpp
|
Clean up GCC warning pragmas
|
2023-04-11 18:21:08 +00:00 |
OpenSSLHelpers.h
|
|
|
OpenTelemetryTraceContext.cpp
|
Add proper escaping for DDL OpenTelemetry context serialization
|
2023-05-20 13:15:49 +02:00 |
OpenTelemetryTraceContext.h
|
Some improvements about names of span logs (#47667)
|
2023-03-29 16:28:36 +02:00 |
OptimizedRegularExpression.cpp
|
address comment
|
2023-05-22 10:41:22 +02:00 |
OptimizedRegularExpression.h
|
address comments
|
2023-03-22 17:47:25 +01:00 |
OvercommitTracker.cpp
|
|
|
OvercommitTracker.h
|
Remove superfluous includes of logger_userful.h from headers
|
2023-04-10 17:59:30 +02:00 |
parseAddress.cpp
|
|
|
parseAddress.h
|
|
|
parseGlobs.cpp
|
|
|
parseGlobs.h
|
|
|
parseRemoteDescription.cpp
|
Fix style
|
2023-05-02 10:38:37 +08:00 |
parseRemoteDescription.h
|
Improve error message for function url
|
2023-05-01 21:40:30 +08:00 |
PipeFDs.cpp
|
|
|
PipeFDs.h
|
|
|
PODArray_fwd.h
|
|
|
PODArray.cpp
|
|
|
PODArray.h
|
Clean up GCC warning pragmas
|
2023-04-11 18:21:08 +00:00 |
PoolBase.h
|
more profile events
|
2023-05-21 12:43:47 +00:00 |
PoolWithFailoverBase.h
|
limit max_tries value by max_error_cap to avoid unlimited number of retries
|
2023-05-19 18:13:29 +00:00 |
Priority.h
|
Unify priorities: lower value means higher priority (#50205)
|
2023-05-26 15:55:30 +02:00 |
ProcfsMetricsProvider.cpp
|
|
|
ProcfsMetricsProvider.h
|
|
|
ProfileEvents.cpp
|
update doc, add profile event WriteBufferFromS3WaitInflightLimitMicroseconds
|
2023-05-26 18:59:21 +02:00 |
ProfileEvents.h
|
Add ProfileEvents for log messages
|
2023-04-22 14:55:25 +02:00 |
ProfileEventsScope.cpp
|
|
|
ProfileEventsScope.h
|
|
|
ProfilingScopedRWLock.h
|
|
|
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
|
|
|
QueryProfiler.h
|
|
|
quoteString.cpp
|
|
|
quoteString.h
|
|
|
RadixSort.h
|
|
|
randomSeed.cpp
|
|
|
randomSeed.h
|
|
|
register_objects.cpp
|
|
|
register_objects.h
|
|
|
remapExecutable.cpp
|
|
|
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
|
Fix some grammar mistakes in documentation, code and tests
|
2023-05-04 13:35:18 -03:00 |
safe_cast.h
|
|
|
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
|
|
|
setThreadName.cpp
|
Allow to run in Linux without PRCTL support
|
2023-05-05 06:40:12 +02:00 |
setThreadName.h
|
|
|
SettingConstraintWritability.h
|
|
|
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
|
|
|
SharedMutex.h
|
|
|
ShellCommand.cpp
|
|
|
ShellCommand.h
|
|
|
shuffle.h
|
|
|
SimpleActionBlocker.h
|
|
|
SimpleIncrement.h
|
Rename "common" to "base"
|
2021-10-02 10:13:14 +03:00 |
SipHash.h
|
Fix IBM
|
2023-04-21 12:38:45 +02:00 |
SLRUCachePolicy.h
|
Query Cache: Implement per-user quotas
|
2023-04-23 16:13:51 +00:00 |
SmallObjectPool.h
|
|
|
SpaceSaving.h
|
Better handling of values too large for VarInt encoding
|
2023-04-11 07:47:33 +00:00 |
StackTrace.cpp
|
Fix error
|
2023-05-06 20:54:52 +02: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
|
Use CLOCK_MONOTONIC_RAW over CLOCK_MONOTONIC on Linux (fixes non monotonic clock)
|
2023-05-12 10:59:53 +02:00 |
StringSearcher.h
|
More cosmetics
|
2023-02-24 10:14:58 +00:00 |
StudentTTest.cpp
|
Remove dangerous code
|
2023-05-06 18:30:18 +02:00 |
StudentTTest.h
|
|
|
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
|
Remove the duplicate pair of parentheses
|
2023-05-28 12:59:34 +08:00 |
TargetSpecific.cpp
|
|
|
TargetSpecific.h
|
Merge branch 'master' into Aggregate_Sum_AVX512
|
2023-02-19 04:03:45 +03:00 |
TaskStatsInfoGetter.cpp
|
|
|
TaskStatsInfoGetter.h
|
|
|
TerminalSize.cpp
|
|
|
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
|
Unify priorities: lower value means higher priority (#50205)
|
2023-05-26 15:55:30 +02:00 |
ThreadPool.h
|
Unify priorities: lower value means higher priority (#50205)
|
2023-05-26 15:55:30 +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
|
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
|
|
|
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
|
|
|
TraceSender.h
|
|
|
TransactionID.cpp
|
|
|
TransactionID.h
|
|
|
TTLCachePolicy.h
|
A bit more memory-safe
|
2023-04-23 18:13:51 +00:00 |
typeid_cast.h
|
Incorporate more review feedback
|
2023-04-05 19:43:30 +00:00 |
TypePromotion.h
|
|
|
UnicodeBar.cpp
|
|
|
UnicodeBar.h
|
|
|
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
|
|
|
Volnitsky.h
|
Fix msan issue in randomStringUTF8(<uneven number>)
|
2023-05-10 17:49:23 +00:00 |
waitForPid.cpp
|
Use __powerpc64__ over __ppc64__ (clang 16 stops declaring __ppc64__)
|
2023-05-09 12:20:50 +02:00 |
waitForPid.h
|
|
|
WeakHash.cpp
|
dbms/ → src/
|
2020-04-03 18:14:31 +03:00 |
WeakHash.h
|
|
|
XMLUtils.cpp
|
|
|
XMLUtils.h
|
|
|