ClickHouse/src/Common
2023-10-10 11:44:06 -03:00
..
benchmarks hashtable order fix for s390x 2023-09-07 07:37:43 -07:00
Config Merge remote-tracking branch 'rschu1ze/master' into mkmkme/fast-configuration 2023-08-31 11:21:23 +00:00
examples Merge branch 'master' into feature/mergetree-checksum-big-endian-support 2023-08-10 10:21:34 -04:00
HashTable big endian 2023-09-22 12:48:31 -07:00
JSONParsers update 2023-09-15 16:05:17 +08:00
mysqlxx Improved protection from dereferencing of nullptr 2023-09-06 01:46:58 +00:00
NamedCollections Continue on garbage removal 2023-08-09 02:58:12 +02:00
SSH SSH keys authentication (#41109) 2023-09-26 17:50:19 +02:00
StringUtils Implemented globs to select * from '<file>' 2023-08-31 04:20:44 +00:00
tests add some tests 2023-10-10 11:44:06 -03:00
ZooKeeper Merge pull request #48855 from ClickHouse/keeper-operation-create-if-not-exists 2023-09-26 16:04:51 +02:00
ActionBlocker.h
ActionLock.cpp
ActionLock.h
AlignedBuffer.cpp Preparation for structured logging 2020-05-31 00:35:52 +03: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 [Resubmit] Remove mmap/mremap/munmap from Allocator.h (#52792) 2023-09-14 13:11:12 +02:00
Allocator.h [Resubmit] Remove mmap/mremap/munmap from Allocator.h (#52792) 2023-09-14 13:11:12 +02:00
AllocatorWithMemoryTracking.h
Arena.h
ArenaAllocator.h
ArenaUtils.h
ArenaWithFreeLists.h
ArrayCache.h
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 Support clang-18 (Wmissing-field-initializers) 2023-08-23 15:53:45 +02: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
Base58.cpp
Base58.h
Base64.cpp
Base64.h
BinStringDecodeHelper.h
BitHelpers.h
BridgeProtocolVersion.h
CacheBase.h Add settings for 1. size_ratio (all caches) and 2. policy (index caches) 2023-08-22 11:04:29 +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 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 Fix calculating stack size under musl for the main thread 2023-09-04 22:01:10 +02:00
checkStackSize.h
clearPasswordFromCommandLine.cpp
clearPasswordFromCommandLine.h
clickhouse_malloc.cpp
ClickHouseRevision.cpp
ClickHouseRevision.h
CMakeLists.txt Use incbin for resources, part 1 2023-07-23 06:11:03 +02:00
ColumnsHashing.h
ColumnsHashingImpl.h
CombinedCardinalityEstimator.h
CompactArray.h
Concepts.h Incorporate more review feedback 2023-04-05 19:43:30 +00:00
ConcurrencyControl.cpp Update src/Common/ConcurrencyControl.cpp 2023-09-12 10:10:20 +10:00
ConcurrencyControl.h
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
CpuId.h
createHardLink.cpp
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 [Resubmit] Remove mmap/mremap/munmap from Allocator.h (#52792) 2023-09-14 13:11:12 +02:00
CurrentMetrics.h
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 More clang-tidy fixes 2023-09-21 14:40:57 +00:00
DNSResolver.h less exceptions with runtime format string 2023-08-14 21:45:59 +02:00
Dwarf.cpp Fix new clang-tidy-s 2023-09-20 22:17:39 +00:00
Dwarf.h
ElapsedTimeProfileEventIncrement.h
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
EnvironmentProxyConfigurationResolver.cpp tmp 2023-10-04 17:21:41 -03:00
EnvironmentProxyConfigurationResolver.h Add global proxy setting (#51749) 2023-08-24 16:07:26 +03: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 Remove Meilisearch 2023-09-30 06:02:38 +02:00
ErrorCodes.h
ErrorHandlers.h
escapeForFileName.cpp
escapeForFileName.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
EventCounter.h
EventFD.cpp
EventFD.h
EventNotifier.cpp
EventNotifier.h Ditch tons of garbage 2023-08-09 02:19:02 +02:00
EventRateMeter.h
Exception.cpp Suppress error statistics update for internal exceptions 2023-09-29 10:58:44 +00:00
Exception.h Suppress error statistics update for internal exceptions 2023-09-29 10:58:44 +00:00
ExponentiallySmoothedCounter.h
ExternalLoaderStatus.h
ExternalModelInfo.h
FailPoint.cpp Test with fail point 2023-09-26 15:19:04 +00:00
FailPoint.h Support setting up fail points in config 2023-08-31 11:45:39 +00:00
Fiber.h Make better 2023-05-22 18:22:05 +00:00
FiberStack.h
FieldVisitorConvertToNumber.h
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
FieldVisitorToString.h
FieldVisitorWriteBinary.cpp
FieldVisitorWriteBinary.h
FileChecker.cpp fix sizes.log writes 2023-05-30 12:26:20 +02:00
FileChecker.h
FileRenamer.cpp Remove broken lockless variant of re2 2023-09-14 16:40:42 +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
filesystemHelpers.h
FileUpdatesTracker.h
format.h Fix msan issue in randomStringUTF8(<uneven number>) 2023-05-10 17:49:23 +00:00
formatIPv6.cpp
formatIPv6.h
formatReadable.cpp
formatReadable.h
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 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 Re-enable clang-tidy checks 2023-09-26 09:34:12 +00:00
getMaxFileDescriptorCount.h
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
getRandomASCIIString.h
hasLinuxCapability.cpp More consistent use of platform macros 2022-06-10 10:22:31 +02:00
hasLinuxCapability.h
HTTPHeaderFilter.cpp Remove broken lockless variant of re2 2023-09-14 16:40:42 +00:00
HTTPHeaderFilter.h Add HTTP header filtering 2023-06-15 13:49:49 +00:00
HyperLogLogBiasEstimator.h
HyperLogLogCounter.h
HyperLogLogWithSmallSetOptimization.h
ICachePolicy.h Some renamings for more consistency 2023-08-22 10:48:03 +00:00
ICachePolicyUserQuota.h
IFactoryWithAliases.h Refactor IHints 2023-09-10 03:48:12 +00:00
Increment.h
InterruptListener.h
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 Mirror change 2023-09-04 15:54:01 +00:00
intExp.h
IO.cpp
IO.h
IPv6ToBinary.cpp
IPv6ToBinary.h
isLocalAddress.cpp Revert "Avoid excessive calls to getifaddrs in isLocalAddress" 2023-09-21 15:57:47 +02:00
isLocalAddress.h
isValidUTF8.cpp
isValidUTF8.h
JSONBuilder.cpp
JSONBuilder.h
KnownObjectNames.cpp
KnownObjectNames.h
likePatternToRegexp.cpp
likePatternToRegexp.h
LocalDate.h cosmetic changes 2023-06-08 16:05:14 +02:00
LocalDateTime.h
LockMemoryExceptionInThread.cpp
LockMemoryExceptionInThread.h
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 Some renamings for more consistency 2023-08-22 10:48:03 +00:00
LRUResourceCache.h
Macros.cpp style check 2023-09-28 19:30:28 +02:00
Macros.h fixed map issue 2023-09-28 17:16:37 +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
memcmpSmall.h AARCH64 Neon memequal wide 2023-08-20 12:45:18 +03:00
memcpySmall.h
memory.h Merge branch 'master' into revert-44629-revert_flamegraph 2023-06-27 17:26:25 +00:00
MemorySanitizer.h
MemoryStatisticsOS.cpp
MemoryStatisticsOS.h
MemoryTracker.cpp Re-enable clang-tidy checks 2023-09-26 09:34:12 +00:00
MemoryTracker.h Fixing a test. 2023-08-03 09:35:45 +00:00
MemoryTrackerBlockerInThread.cpp
MemoryTrackerBlockerInThread.h
MemoryTrackerSwitcher.h Fix using of pools from the main thread 2023-07-09 14:21:27 +02:00
MultiVersion.h
NamePrompter.cpp
NamePrompter.h Refactor IHints 2023-09-10 03:48:12 +00:00
NaNUtils.h
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
ObjectPool.h
OpenSSLHelpers.cpp
OpenSSLHelpers.h
OpenTelemetryTraceContext.cpp Re-enable clang-tidy checks 2023-09-26 09:34:12 +00:00
OpenTelemetryTraceContext.h
OptimizedRegularExpression.cpp Allow LIKE over binary data 2023-09-23 04:14:03 +02:00
OptimizedRegularExpression.h Remove broken lockless variant of re2 2023-09-14 16:40:42 +00:00
OvercommitTracker.cpp
OvercommitTracker.h
parseAddress.cpp
parseAddress.h
parseGlobs.cpp Remove broken lockless variant of re2 2023-09-14 16:40:42 +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
PipeFDs.h
PODArray_fwd.h
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
ProcfsMetricsProvider.h
ProfileEvents.cpp ProfileEvents added ContextLockWaitMicroseconds 2023-09-26 19:08:22 +03:00
ProfileEvents.h Add ProfileEvents::Timer class 2023-09-03 13:32:25 +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 tmp 2023-10-04 17:21:41 -03:00
ProxyConfigurationResolver.h Add global proxy setting (#51749) 2023-08-24 16:07:26 +03:00
ProxyConfigurationResolverProvider.cpp tmp 2023-10-04 17:21:41 -03:00
ProxyConfigurationResolverProvider.h tmp 2023-10-04 17:21:41 -03:00
ProxyListConfigurationResolver.cpp Add global proxy setting (#51749) 2023-08-24 16:07:26 +03:00
ProxyListConfigurationResolver.h Add global proxy setting (#51749) 2023-08-24 16:07:26 +03: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
randomSeed.cpp Implement endianness-independent SipHash and MergeTree checksum serialization 2023-07-19 10:01:55 -07:00
randomSeed.h
register_objects.cpp Automated function registration 2022-07-29 15:39:50 +08:00
register_objects.h
remapExecutable.cpp
remapExecutable.h
RemoteHostFilter.cpp Remove broken lockless variant of re2 2023-09-14 16:40:42 +00:00
RemoteHostFilter.h
RemoteProxyConfigurationResolver.cpp Add global proxy setting (#51749) 2023-08-24 16:07:26 +03:00
RemoteProxyConfigurationResolver.h Add global proxy setting (#51749) 2023-08-24 16:07:26 +03:00
RWLock.cpp
RWLock.h
safe_cast.h
scope_guard_safe.h
SensitiveDataMasker.cpp Remove broken lockless variant of re2 2023-09-14 16:40:42 +00:00
SensitiveDataMasker.h
setThreadName.cpp do not fail if prctl is not allowed 2023-08-07 17:03:48 +02:00
setThreadName.h
SettingConstraintWritability.h
SettingsChanges.cpp
SettingsChanges.h
SettingSource.h Implemented max sessions for user 2023-07-30 22:09:03 +00:00
SharedBlockRowRef.h
SharedMutex.cpp fix try_shared_lock() in SharedMutex and CancelableSharedMutex 2023-01-24 14:36:07 +00:00
SharedMutex.h
ShellCommand.cpp Fix data race of shell command 2023-08-22 14:50:56 +08:00
ShellCommand.h
ShellCommandSettings.cpp Refactor 2023-08-18 15:38:46 +08:00
ShellCommandSettings.h Refactor 2023-08-18 15:38:46 +08:00
shuffle.h
SimpleActionBlocker.h
SimpleIncrement.h
SipHash.h Merge remote-tracking branch 'upstream/master' into HEAD 2023-09-18 23:13:20 +00:00
SLRUCachePolicy.h Some renamings for more consistency 2023-08-22 10:48:03 +00:00
SmallObjectPool.h
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
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 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 Add backup_log table 2023-08-10 15:46:04 +03:00
SystemLogBase.h Merge branch 'master' into ADQM-987 2023-08-14 10:33:56 +03:00
TargetSpecific.cpp Re-enable clang-tidy checks 2023-09-26 09:34:12 +00:00
TargetSpecific.h
TerminalSize.cpp
TerminalSize.h
thread_local_rng.cpp
thread_local_rng.h
ThreadFuzzer.cpp
ThreadFuzzer.h
ThreadPool_fwd.h
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
ThreadStatus.cpp cut the build dependency between commin_io and other libraries 2023-09-28 00:15:36 +02:00
ThreadStatus.h cut the build dependency between commin_io and other libraries 2023-09-28 00:15:36 +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 Don't use default move assignment in TimerDescriptor 2023-09-19 11:45:53 +00:00
TimerDescriptor.h Don't use default move assignment in TimerDescriptor 2023-09-19 11:45:53 +00:00
TLDListsHolder.cpp
TLDListsHolder.h
TraceSender.cpp
TraceSender.h
TransactionID.cpp
TransactionID.h
TransformEndianness.hpp Eliminate duplicate include 2023-08-15 13:54:28 +00:00
TTLCachePolicy.h Some renamings for more consistency 2023-08-22 10:48:03 +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 Remove redundant enumerator 2021-10-12 13:46:32 +03:00
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 Use __powerpc64__ over __ppc64__ (clang 16 stops declaring __ppc64__) 2023-05-09 12:20:50 +02:00
waitForPid.h
WeakHash.cpp
WeakHash.h
XMLUtils.cpp
XMLUtils.h