ClickHouse/src/Common
Han Fei f3684f78b7
Merge pull request #51720 from arenadata/ADQM-970
Added a crash log flush to the disk after the unexpected crash.
2023-07-13 10:49:07 +02:00
..
benchmarks
Config fix 2023-07-11 12:27:23 +00:00
examples Cleanup SymbolIndex after reload got removed 2023-07-09 09:25:11 +02:00
HashTable Merge pull request #49380 from azat/dict/hashed-memory 2023-05-21 15:46:41 +02:00
JSONParsers
mysqlxx Fix crash when Pool::Entry::disconnect() is called 2023-05-30 10:29:49 +02:00
NamedCollections
StringUtils
tests Merge pull request #50315 from arenadata/ADQM-810 2023-06-01 16:19:14 +02:00
ZooKeeper Merge pull request #50796 from ClickHouse/keeper-add-api-version-config 2023-06-30 09:20:52 +02:00
ActionBlocker.h
ActionLock.cpp
ActionLock.h
AlignedBuffer.cpp
AlignedBuffer.h
Allocator_fwd.h
Allocator.cpp Play with MMAP_THRESHOLD (set it to 128MiB) 2023-04-19 22:40:13 +02:00
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 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 Make better 2023-05-22 18:22:05 +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 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
CancelToken.h
CaresPTRResolver.cpp
CaresPTRResolver.h
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
clearPasswordFromCommandLine.h
clickhouse_malloc.cpp
ClickHouseRevision.cpp
ClickHouseRevision.h
CMakeLists.txt
ColumnsHashing.h
ColumnsHashingImpl.h
CombinedCardinalityEstimator.h
CompactArray.h
Concepts.h
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
config_version.h.in
config.h.in Force libunwind usage (removes gcc_eh support) 2023-07-08 20:55:50 +02:00
CounterInFile.h
COW.h
CpuId.h
createHardLink.cpp
createHardLink.h
CurrentMemoryTracker.cpp
CurrentMemoryTracker.h
CurrentMetrics.cpp Merge branch 'master' into clickhouse_as_library_2 2023-07-09 08:47:53 +03:00
CurrentMetrics.h
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 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 Better naming and comments 2023-06-24 07:14:21 +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
DNSPTRResolverProvider.cpp
DNSPTRResolverProvider.h
DNSResolver.cpp an optimiation for alters and replicated db 2023-06-15 20:20:11 +02:00
DNSResolver.h
Dwarf.cpp
Dwarf.h
ElapsedTimeProfileEventIncrement.h
Elf.cpp
Elf.h
Epoll.cpp
Epoll.h
ErrorCodes.cpp Try to fix style issues 2023-07-06 11:48:22 +08:00
ErrorCodes.h
ErrorHandlers.h
escapeForFileName.cpp
escapeForFileName.h
EventCounter.h
EventFD.cpp
EventFD.h
EventNotifier.cpp
EventNotifier.h
EventRateMeter.h
Exception.cpp Merge pull request #51135 from ClickHouse/fix_trash_in_disks 2023-07-07 02:02:17 +03:00
Exception.h added setting 'enable_job_stack_trace', default is off 2023-06-28 01:39:06 +00: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 Make better 2023-05-22 18:22:05 +00:00
FiberStack.h
FieldVisitorConvertToNumber.h
FieldVisitorDump.cpp
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 Fix style 2023-05-19 16:03:22 +00:00
FileRenamer.h Added option to rename files, loaded via TableFunctionFile, after success processing 2023-05-19 16:03:22 +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.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
getExecutablePath.h
getHashOfLoadedBinary.cpp Support getHexUIntLowercase() with CityHash_v1_0_2::uint128 parameter. 2023-06-29 15:29:37 +02:00
getHashOfLoadedBinary.h
getMappedArea.cpp
getMappedArea.h
getMaxFileDescriptorCount.cpp
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
getResource.cpp Cleanup SymbolIndex after reload got removed 2023-07-09 09:25:11 +02:00
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
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 introduce LogSeriesLimiterPtrt 2023-06-23 23:06:32 +02:00
LoggingFormatStringHelpers.cpp initialize SeriesRecords for LogSeriesLimiter lazy 2023-07-06 19:49:22 +02:00
LoggingFormatStringHelpers.h initialize SeriesRecords for LogSeriesLimiter lazy 2023-07-06 19:49:22 +02:00
LRUCachePolicy.h Query Cache: Implement per-user quotas 2023-04-23 16:13:51 +00:00
LRUResourceCache.h
Macros.cpp
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
memcpySmall.h
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
MemoryTrackerSwitcher.h don't account session's memory in thread/user mem tracker 2023-07-06 14:41:03 +02:00
MultiVersion.h
NamePrompter.cpp
NamePrompter.h
NaNUtils.h
NetException.h
new_delete.cpp
noexcept_scope.h
ObjectPool.h
OpenSSLHelpers.cpp Clean up GCC warning pragmas 2023-04-11 18:21:08 +00:00
OpenSSLHelpers.h
OpenTelemetryTraceContext.cpp Merge pull request #49287 from nickitat/optimize_reading2 2023-06-02 23:51:57 +03:00
OpenTelemetryTraceContext.h
OptimizedRegularExpression.cpp Follow-up to re2 update 2023-06-02 (#50949) 2023-07-03 08:28:25 +00:00
OptimizedRegularExpression.h Follow-up to re2 update 2023-06-02 (#50949) 2023-07-03 08:28:25 +00:00
OvercommitTracker.cpp
OvercommitTracker.h
parseAddress.cpp
parseAddress.h
parseGlobs.cpp Follow-up to re2 update 2023-06-02 (#50949) 2023-07-03 08:28:25 +00:00
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 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 Merge branch 'master' into clickhouse_as_library_2 2023-07-09 08:47:53 +03: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 useless code 2023-06-01 03:04:29 +02:00
ProgressIndication.h
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
quoteString.h
RadixSort.h
randomSeed.cpp
randomSeed.h
register_objects.cpp
register_objects.h
remapExecutable.cpp
remapExecutable.h
RemoteHostFilter.cpp
RemoteHostFilter.h
RWLock.cpp
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
SensitiveDataMasker.cpp Follow-up to re2 update 2023-06-02 (#50949) 2023-07-03 08:28:25 +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
SettingsChanges.h
SharedBlockRowRef.h
SharedMutex.cpp
SharedMutex.h
ShellCommand.cpp do call finalize for all buffers 2023-06-16 16:38:18 +02:00
ShellCommand.h
shuffle.h
SimpleActionBlocker.h
SimpleIncrement.h
SipHash.h Inline SipHash::get128(char *) 2023-07-11 23:17:55 +08:00
SLRUCachePolicy.h Query Cache: Implement per-user quotas 2023-04-23 16:13:51 +00:00
SmallObjectPool.h
SpaceSaving.h
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
StatusInfo.cpp StatusInfo will be deprecated 2023-07-06 11:48:21 +08:00
StatusInfo.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 Remove dangerous code 2023-05-06 18:30:18 +02:00
StudentTTest.h
SymbolIndex.cpp Cleanup SymbolIndex after reload got removed 2023-07-09 09:25:11 +02:00
SymbolIndex.h Cleanup SymbolIndex after reload got removed 2023-07-09 09:25:11 +02:00
SystemLogBase.cpp style correction 2023-07-04 02:45:15 +00:00
SystemLogBase.h Added waiting before crash log store finish 2023-07-04 02:32:08 +00:00
TargetSpecific.cpp
TargetSpecific.h
TaskStatsInfoGetter.cpp Update src/Common/TaskStatsInfoGetter.cpp 2023-06-02 12:34:22 +02:00
TaskStatsInfoGetter.h
TerminalSize.cpp
TerminalSize.h
thread_local_rng.cpp
thread_local_rng.h
ThreadFuzzer.cpp
ThreadFuzzer.h
ThreadPool_fwd.h
ThreadPool.cpp style fix 2023-06-28 19:53:49 +00:00
ThreadPool.h added setting 'enable_job_stack_trace', default is off 2023-06-28 01:39:06 +00:00
ThreadProfileEvents.cpp
ThreadProfileEvents.h
ThreadStatus.cpp Better check for current_thread 2023-07-07 11:39:41 +00:00
ThreadStatus.h Remove maybe_unused 2023-07-07 11:41:01 +00: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
TLDListsHolder.h Reduce the usage of Arena.h 2023-04-13 10:31:32 +02:00
TraceSender.cpp
TraceSender.h
TransactionID.cpp
TransactionID.h
TransformEndianness.hpp Remove unnecessary conditional expression 2023-06-05 15:34:04 +00:00
TTLCachePolicy.h A bit more memory-safe 2023-04-23 18:13:51 +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
UnicodeBar.h
UTF8Helpers.cpp
UTF8Helpers.h
VariableContext.h
VersionNumber.cpp
VersionNumber.h
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