ClickHouse/src/Common
Pablo Marcos 200c54df80
Merge pull request #67219 from pamarcos/fix-crash-in-distributed-async-insert-directory-queue
[Green CI] Fix crash in DistributedAsyncInsert when connection is empty
2024-07-31 08:30:35 +00:00
..
benchmarks Remove old code 2024-03-04 00:11:55 +01:00
Config impl 2024-07-17 16:59:31 +01:00
examples Fix build 2024-07-24 19:51:22 +02:00
HashTable Merge pull request #62746 from jiebinn/FixedHashTable 2024-05-28 12:06:53 +00:00
JSONParsers Refactor JSONExtract functions and support more types and reuse its code in new JSON type 2024-07-03 13:40:41 +00:00
mysqlxx Fix build 2024-07-26 10:59:17 +02:00
NamedCollections Fix style 2024-07-17 15:28:08 +00:00
Scheduler fix tidy build 2024-06-18 19:12:58 +00:00
tests Merge branch 'chesema-fix-BannedForConsiquenceFail' of github.com:ClickHouse/ClickHouse into fix-distributed-analyzer 2024-07-24 02:53:11 +02:00
ZooKeeper Merge branch 'fix-data-race-in-zookeeper' of github.com:ClickHouse/ClickHouse into fix-data-race-in-zookeeper 2024-07-27 12:10:58 +02: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
Allocator_fwd.h
Allocator.cpp Correctly handle failure 2024-07-21 11:41:42 +02:00
Allocator.h Move Allocator code into module part 2023-12-27 15:42:08 +01:00
AllocatorWithMemoryTracking.h Enable clang-tidy in headers 2024-03-18 08:00:09 +00:00
Arena.h Enable clang-tidy in headers 2024-03-18 08:00:09 +00:00
ArenaAllocator.h Avoid excessive allocation in Arena 2023-11-22 12:13:47 +01:00
ArenaUtils.h
ArenaWithFreeLists.h Useless changes 2024-05-09 03:11:02 +02:00
ArrayCache.h Remove workaround for old enough MacOSX 2023-12-27 15:42:08 +01:00
assert_cast.h impl 2024-07-17 16:59:31 +01:00
assertProcessUserMatchesDataOwner.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
assertProcessUserMatchesDataOwner.h
AsynchronousMetrics.cpp [fix] remove static from function 2024-06-14 16:12:59 +08:00
AsynchronousMetrics.h Add useful comment 2024-06-10 12:48:32 +02:00
AsyncLoader.cpp proper destruction order of AsyncLoader::Pool fields 2024-07-05 15:06:50 +00:00
AsyncLoader.h proper destruction order of AsyncLoader::Pool fields 2024-07-05 15:06:50 +00:00
AsyncTaskExecutor.cpp
AsyncTaskExecutor.h Useless changes 2024-05-09 01:08:33 +02:00
AtomicLogger.h Modify the code for build with new libcxx 2024-07-09 20:16:43 +00:00
atomicRename.cpp Initial support for loongarch64 2024-05-14 07:45:26 +00:00
atomicRename.h
Base58.cpp Useless changes 2024-05-10 03:31:40 +02:00
Base58.h
Base64.cpp
Base64.h
BinStringDecodeHelper.h impl 2024-07-04 18:56:26 +01:00
BitHelpers.h Add missing includes into BitHelpers.h 2023-12-27 17:06:17 +01:00
BridgeProtocolVersion.h
BufferAllocationPolicy.cpp Fix S3 buffer allocation 2024-03-21 19:18:16 +01:00
BufferAllocationPolicy.h Updated lambda and name of BufferAllocationPolicy 2024-03-21 11:10:54 +01:00
CacheBase.h Incorporate review feedback 2024-01-11 13:53:08 +00:00
CalendarTimeInterval.cpp Update to clang-19 2024-02-27 14:37:21 +01:00
CalendarTimeInterval.h Things 2023-12-28 17:56:05 +00:00
callOnce.h
CancelableSharedMutex.cpp
CancelableSharedMutex.h
CancelToken.cpp
CancelToken.h
CaresPTRResolver.cpp remove unused cancel_requests method 2024-05-14 12:53:31 +02:00
CaresPTRResolver.h remove unused cancel_requests method 2024-05-14 12:53:31 +02:00
CgroupsMemoryUsageObserver.cpp add unit tests 2024-07-18 19:04:42 +01:00
CgroupsMemoryUsageObserver.h add unit tests 2024-07-18 19:04:42 +01:00
checkSSLReturnCode.cpp
checkSSLReturnCode.h
checkStackSize.cpp Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
checkStackSize.h
clearPasswordFromCommandLine.cpp
clearPasswordFromCommandLine.h
clickhouse_malloc.cpp Better 2024-05-24 17:03:49 +02:00
ClickHouseRevision.cpp Fix build 2023-11-13 10:09:23 +01:00
ClickHouseRevision.h
CMakeLists.txt Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00:00
CollectionOfDerived.h fix CollectionOfDerivedItems::append to appendIfUniq 2024-07-18 16:42:47 +02:00
ColumnsHashing.h Merge branch 'master' of github.com:ClickHouse/ClickHouse into clang-18-ci 2024-05-10 07:17:39 +02:00
ColumnsHashingImpl.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
CombinedCardinalityEstimator.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
CompactArray.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
Concepts.h
ConcurrencyControl.cpp split ISlotControl from ConcurrencyControl 2024-01-28 20:26:55 +00:00
ConcurrencyControl.h Modify the code for build with new libcxx 2024-07-09 20:16:43 +00:00
ConcurrentBoundedQueue.h Fix data race for Keeper snapshot queue 2024-07-02 10:36:20 +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 Try calcualting memory with numactl if membind used 2024-07-25 11:49:02 +02:00
CopyableAtomic.h Avoid taking lock 2024-06-04 14:57:43 +02:00
CounterInFile.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
Coverage.cpp Fix includes 2024-07-03 18:48:32 +02:00
Coverage.h Reuse some checks 2024-07-03 16:54:09 +02:00
COW.h
CPUID.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
createHardLink.cpp Review error codes 2023-12-18 10:40:02 +01:00
createHardLink.h
CurrentMemoryTracker.cpp Revert "Add dynamic untracked memory limits for more precise memory tracking" 2024-06-07 14:03:56 +02:00
CurrentMemoryTracker.h Revert "Add dynamic untracked memory limits for more precise memory tracking" 2024-06-07 14:03:56 +02:00
CurrentMetrics.cpp Miscellaneous 2024-07-21 10:32:54 +02:00
CurrentMetrics.h Remove some code 2024-01-13 03:48:04 +01:00
CurrentThread.cpp
CurrentThread.h Minor corrections 2024-05-19 13:00:30 +00:00
CurrentThreadHelpers.cpp Remove a few nested include dependencies 2024-04-02 13:43:14 +02:00
CurrentThreadHelpers.h Remove a few nested include dependencies 2024-04-02 13:43:14 +02:00
DateLUT.cpp Hide Settings object from Context.h 2024-07-11 14:00:05 +02:00
DateLUT.h Remove nested dependency on DateLutImpl 2024-04-02 14:45:48 +02:00
DateLUTImpl.cpp Reapply "Remove some unnecessary UNREACHABLEs" 2024-05-29 13:37:47 +00:00
DateLUTImpl.h Useless changes 2024-05-09 02:07:04 +02:00
DNSPTRResolver.h
DNSPTRResolverProvider.cpp
DNSPTRResolverProvider.h
DNSResolver.cpp Fix clang-tidy-s 2024-03-11 10:58:54 +00:00
DNSResolver.h Fix clang-tidy-s 2024-03-11 10:58:54 +00:00
Dwarf.cpp Fix Dwarf range list parsing in stack symbolizer 2024-07-29 23:12:12 +00:00
Dwarf.h Useless changes 2024-05-09 01:08:33 +02:00
ElapsedTimeProfileEventIncrement.h Fix ProfileEventTimeIncrement code 2024-05-07 21:11:17 +02:00
Elf.cpp
Elf.h
EnvironmentChecks.cpp Reuse some checks 2024-07-03 16:54:09 +02:00
EnvironmentChecks.h Reuse some checks 2024-07-03 16:54:09 +02:00
EnvironmentProxyConfigurationResolver.cpp safe guard around no proxy strings 2024-06-10 11:17:10 -03:00
EnvironmentProxyConfigurationResolver.h fix tunneling 2024-06-05 13:46:45 -03: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 Minor changes found reviewing to remove the draft status 2024-06-18 15:42:57 +00:00
ErrorCodes.h Minor changes found reviewing to remove the draft status 2024-06-18 15:42:57 +00:00
ErrorHandlers.h Updated implementation 2024-01-25 14:31:49 +03:00
escapeForFileName.cpp Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +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
EventRateMeter.h
Exception.cpp Fix linking 2024-07-26 16:23:29 +02:00
Exception.h More fixes 2024-07-26 10:47:32 +02:00
ExponentiallySmoothedCounter.h
ExternalLoaderStatus.cpp Update ExternalLoaderStatus.cpp 2024-03-24 04:14:32 +03:00
ExternalLoaderStatus.h Remove some inclusion of magic enum 2024-03-20 17:00:36 +00:00
ExternalModelInfo.h
FailPoint.cpp Handle better static destructors 2024-07-24 12:04:28 +02:00
FailPoint.h Remove old code 2024-03-04 00:11:55 +01:00
Fiber.h Revert "Revert "Check stack size in Parser"" 2024-02-27 01:34:50 +03:00
FiberStack.h Move Allocator code into module part 2023-12-27 15:42:08 +01:00
FieldBinaryEncoding.cpp Fix style 2024-06-21 19:22:10 +00:00
FieldBinaryEncoding.h Implement binary encoding for ClickHouse data types 2024-06-21 18:20:35 +00:00
FieldVisitorConvertToNumber.cpp More explicit template instantiations (#60730) 2024-03-07 17:16:13 +01:00
FieldVisitorConvertToNumber.h More explicit template instantiations (#60730) 2024-03-07 17:16:13 +01:00
FieldVisitorDump.cpp
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 Remove more nested includes 2024-04-03 19:06:36 +02:00
FileChecker.h Fixing more headers 2024-02-29 15:40:30 +00:00
FileRenamer.cpp Some fixups 2024-01-07 22:28:08 +00:00
FileRenamer.h Fixing more headers 2024-02-29 15:40:30 +00:00
filesystemHelpers.cpp remove unnecessary change 2024-06-12 04:32:34 +00:00
filesystemHelpers.h Useless changes 2024-05-09 01:08:33 +02:00
FileUpdatesTracker.h
findExtreme.cpp Restore the warning 2024-05-19 12:51:14 +00:00
findExtreme.h Implement findExtremeMinIndex / findExtremeMaxIndex 2024-01-17 16:22:40 +01:00
format.h Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00:00
formatIPv6.cpp Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00:00
formatIPv6.h Random header fixes for libcxx 16 2024-07-04 15:39:50 +00:00
formatReadable.cpp Fix error 2024-03-23 04:41:07 +01:00
formatReadable.h update fmtlib version to 9.1.0 2024-06-07 06:44:36 +00:00
FrequencyHolder.cpp Updated implementation 2024-01-25 14:31:49 +03:00
FrequencyHolder.h Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00:00
FST.cpp Useless changes 2024-05-10 03:31:40 +02:00
FST.h Useless changes 2024-05-12 18:22:41 +02:00
FunctionDocumentation.cpp Use boost::algorithm::join 2024-03-11 10:33:09 +00:00
FunctionDocumentation.h
futex.h Useless changes 2024-05-09 02:07:04 +02:00
getCurrentProcessFDCount.cpp
getCurrentProcessFDCount.h
getExecutablePath.cpp
getExecutablePath.h
getHashOfLoadedBinary.cpp
getHashOfLoadedBinary.h
getMappedArea.cpp Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00:00
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 Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00:00
getMultipleKeysFromConfig.h
getNumberOfPhysicalCPUCores.cpp Some minor fixups 2024-07-15 08:47:08 +00:00
getNumberOfPhysicalCPUCores.h
GetPriorityForLoadBalancing.cpp Merge remote-tracking branch 'blessed/master' into mergetree_private 2024-07-11 19:58:54 +02:00
GetPriorityForLoadBalancing.h Merge remote-tracking branch 'blessed/master' into mergetree_private 2024-07-11 19:58:54 +02:00
getRandomASCIIString.cpp Add randomized test FullSortingJoin.AsofGeneratedTestData 2024-06-12 08:45:36 +00:00
getRandomASCIIString.h Add randomized test FullSortingJoin.AsofGeneratedTestData 2024-06-12 08:45:36 +00:00
GWPAsan.cpp Don't start GWP allocations until init is finished 2024-07-19 13:34:50 +00:00
GWPAsan.h Don't start GWP allocations until init is finished 2024-07-19 13:34:50 +00:00
hasLinuxCapability.cpp Use 64-bit capabilities if available 2024-03-04 16:20:45 +01:00
hasLinuxCapability.h
HilbertUtils.h fix 2024-06-17 03:41:25 +03:00
HostResolvePool.cpp add unit tests, add new counter AddressesBanned 2024-05-13 20:34:45 +02:00
HostResolvePool.h add unit tests, add new counter AddressesBanned 2024-05-13 20:34:45 +02:00
HTTPConnectionPool.cpp keep no_proxy string as is in clickhouse memory, convert to or-based regex with match anything wildcard for poco 2024-05-03 11:48:50 -03:00
HTTPConnectionPool.h Useless changes 2024-05-09 01:08:33 +02:00
HTTPHeaderFilter.cpp Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00:00
HTTPHeaderFilter.h
HyperLogLogBiasEstimator.h
HyperLogLogCounter.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
HyperLogLogWithSmallSetOptimization.h
ICachePolicy.h Delete test 2024-06-20 18:44:45 +00:00
ICachePolicyUserQuota.h QueryCache: Fix odd bugs with user quota 2024-01-12 14:27:37 +00:00
IFactoryWithAliases.h Make CaseSensitiveness an enum class 2024-07-17 20:56:30 +00:00
Increment.h
InterruptListener.h Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
IntervalKind.cpp Reapply "Remove some unnecessary UNREACHABLEs" 2024-05-29 13:37:47 +00:00
IntervalKind.h Implement binary encoding for ClickHouse data types 2024-06-21 18:20:35 +00:00
IntervalTree.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
intExp.h Useless changes 2024-05-09 02:07:04 +02:00
IO.cpp
IO.h
iota.cpp Resolved issues 2024-03-20 13:20:39 +00:00
iota.h Resolved issues 2024-03-20 13:20:39 +00:00
IPv6ToBinary.cpp
IPv6ToBinary.h
isLocalAddress.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
isLocalAddress.h
ISlotControl.h Update src/Common/ISlotControl.h 2024-02-01 13:52:56 +01:00
isValidUTF8.cpp
isValidUTF8.h
Jemalloc.cpp Fixes 2024-07-04 13:57:47 +02:00
Jemalloc.h Fixes 2024-07-04 13:57:47 +02:00
JSONBuilder.cpp
JSONBuilder.h
KnownObjectNames.cpp
KnownObjectNames.h
levenshteinDistance.cpp More iota 2023-12-29 17:20:18 +01:00
levenshteinDistance.h
likePatternToRegexp.cpp
likePatternToRegexp.h
LocalDate.h Remove nested dependency on DateLutImpl 2024-04-02 14:45:48 +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 Add columns for values used in the formatting message into system.text_log 2024-04-23 17:26:56 +01:00
Logger.cpp Fix linking 2024-07-26 16:23:29 +02:00
Logger.h Fix linking 2024-07-26 16:23:29 +02:00
LoggingFormatStringHelpers.cpp Useless changes 2024-05-09 03:11:02 +02:00
LoggingFormatStringHelpers.h Useless changes 2024-05-09 02:07:04 +02:00
LRUCachePolicy.h
LRUResourceCache.h fix LRUResource Cache bug 2024-02-22 10:41:16 +08: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 old code 2024-03-04 00:11:55 +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 Update memcpySmall.h 2024-03-08 13:47:35 +08:00
memory.h Don't start GWP allocations until init is finished 2024-07-19 13:34:50 +00:00
MemorySanitizer.h Remove old code 2024-03-04 00:11:55 +01:00
MemoryStatisticsOS.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
MemoryStatisticsOS.h
MemoryTracker.cpp impl 2024-07-17 16:59:31 +01: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 untacked memory in MemoryTrackerSwitcher 2024-06-05 13:10:37 +00:00
MortonUtils.h Useless changes 2024-05-10 04:53:29 +02:00
MultiVersion.h Fix clang-tidy-s 2024-03-11 10:58:54 +00:00
NamePrompter.cpp
NamePrompter.h Do not include PODArray.h into NamePrompter.h 2023-12-27 15:42:08 +01:00
NaNUtils.h Check boundaries for some settings in parallel replicas (#61455) 2024-03-18 12:06:45 +01:00
NetException.h Useless changes 2024-05-10 04:53:29 +02:00
NetlinkMetricsProvider.cpp Useless changes 2024-05-09 03:11:02 +02:00
NetlinkMetricsProvider.h
new_delete.cpp Fix typo in new_delete.cpp 2024-07-15 21:29:52 +02: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 S3-plain based disk supporting directory rename 2024-04-29 18:01:21 +00:00
ObjectStorageKeyGenerator.h S3-plain based disk supporting directory rename 2024-04-29 18:01:21 +00:00
OpenSSLHelpers.cpp
OpenSSLHelpers.h
OpenTelemetryTraceContext.cpp Move Allocator code into module part 2023-12-27 15:42:08 +01:00
OpenTelemetryTraceContext.h Useless changes 2024-05-09 02:07:04 +02:00
OptimizedRegularExpression.cpp Useless changes 2024-05-09 03:11:02 +02:00
OptimizedRegularExpression.h Some fixups 2024-01-07 22:28:08 +00:00
OvercommitTracker.cpp
OvercommitTracker.h Useless changes 2024-05-09 01:08:33 +02:00
PageCache.cpp impl 2024-07-17 16:59:31 +01:00
PageCache.h Useless changes 2024-05-09 01:08:33 +02:00
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 Handle better static destructors 2024-07-24 12:04:28 +02:00
PipeFDs.h Handle better static destructors 2024-07-24 12:04:28 +02:00
PODArray_fwd.h Useless changes 2024-05-09 02:07:04 +02:00
PODArray.cpp inline another function 2024-03-11 14:44:16 +08:00
PODArray.h Small fix 2024-06-03 15:01:03 +02:00
PoolBase.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
PoolId.h comment 2023-11-07 10:24:56 +00:00
PoolWithFailoverBase.h Ensure there's no logical error using PoolWithFailoverBase::getMany 2024-07-29 16:27:12 +00:00
Priority.h
ProcfsMetricsProvider.cpp Better text_log with ErrnoException 2023-12-15 19:27:56 +01:00
ProcfsMetricsProvider.h
ProfileEvents.cpp relax condition in test, remove unused counters 2024-07-18 19:55:09 +02:00
ProfileEvents.h Sync changes 2024-06-13 15:14:05 +02:00
ProfileEventsScope.cpp Remove a few nested include dependencies 2024-04-02 13:43:14 +02:00
ProfileEventsScope.h Remove a few nested include dependencies 2024-04-02 13:43:14 +02:00
ProfilingScopedRWLock.h
ProgressIndication.cpp Random missing headers 2024-07-12 00:00:47 +02:00
ProgressIndication.h Merge branch 'master' into vdimir/client-noninteractive-mem-usage 2024-07-15 11:34:37 +02:00
ProxyConfiguration.h Fix AWS ECS 2024-06-12 14:08:52 +02:00
ProxyConfigurationResolver.h fix tunneling 2024-06-05 13:46:45 -03:00
ProxyConfigurationResolverProvider.cpp Revert "Fix AWS ECS" 2024-06-17 23:11:59 +02:00
ProxyConfigurationResolverProvider.h Revert "Fix AWS ECS" 2024-06-17 23:11:59 +02:00
proxyConfigurationToPocoProxyConfig.cpp safe guard around no proxy strings 2024-06-10 11:17:10 -03:00
proxyConfigurationToPocoProxyConfig.h build poco no proxy only once 2024-06-05 09:52:42 -03:00
ProxyListConfigurationResolver.cpp fix no proxy hosts for remote and list resolvers 2024-06-06 09:48:48 -03:00
ProxyListConfigurationResolver.h reorder args and adapt tests 2024-05-06 17:02:20 -03:00
QueryProfiler.cpp uncomment also write_trace_iteration 2024-07-25 20:23:45 +00:00
QueryProfiler.h [RFC] Try to add global Real and CPU trace collector 2024-04-02 18:04:53 +02:00
quoteString.cpp
quoteString.h
RadixSort.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
randomDelay.cpp Add test. 2024-04-02 23:44:49 +02:00
randomDelay.h Add test. 2024-04-02 23:44:49 +02: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 Remove old code 2024-03-04 00:11:55 +01: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 Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00:00
RemoteHostFilter.h Modify the code for build with new libcxx 2024-07-09 20:16:43 +00:00
RemoteProxyConfigurationResolver.cpp fix tunneling 2024-06-05 13:46:45 -03:00
RemoteProxyConfigurationResolver.h Merge branch 'master' into no_proxy_support 2024-06-04 14:55:12 -03: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 Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00: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 Useless changes 2024-05-09 01:08:33 +02:00
SettingsChanges.cpp
SettingsChanges.h
SettingSource.h
SharedLockGuard.h Convert unnecessary std::scoped_lock to std::lock_guard 2023-10-25 09:26:16 +00:00
SharedMutex.cpp Set writer_thread_id earlier, when new exclusive owener is waiting for existing readers to finish 2024-07-22 12:11:56 +02:00
SharedMutex.h Set writer_thread_id earlier, when new exclusive owener is waiting for existing readers to finish 2024-07-22 12:11:56 +02:00
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
ShellCommandSettings.h Useless changes 2024-05-09 01:08:33 +02:00
shuffle.h
SignalHandlers.cpp More fixes 2024-07-26 10:47:32 +02:00
SignalHandlers.h Blind fix for build 2024-03-12 02:55:23 +01:00
SimpleIncrement.h
SipHash.h Fix clang-tidy-s 2024-03-11 10:58:54 +00:00
SLRUCachePolicy.h
SpaceSaving.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
SSHWrapper.cpp Cleanup SSH-based authentication code 2024-04-05 08:43:23 +00:00
SSHWrapper.h Cleanup SSH-based authentication code 2024-04-05 08:43:23 +00:00
StackTrace.cpp More fixes 2024-07-26 10:47:32 +02:00
StackTrace.h Print stacktrace in case of about after logical error. 2024-07-04 13:44:44 +00:00
StatusFile.cpp Fix abort on uncaught exception in ~WriteBufferFromFileDescriptor in StatusFile 2024-05-21 18:46:21 +00:00
StatusFile.h
Stopwatch.h Useless changes 2024-05-09 02:07:04 +02:00
StringSearcher.h Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00:00
StringUtils.cpp Move isAllASCII from UTF8Helpers to StringUtils 2024-05-19 09:39:48 +00:00
StringUtils.h Refactor change and add failing test case 2024-06-03 16:34:53 +02:00
StudentTTest.cpp Useless changes 2024-05-09 03:11:02 +02:00
StudentTTest.h
SymbolIndex.cpp Useless changes 2024-05-09 03:11:02 +02:00
SymbolIndex.h
SystemLogBase.cpp Merge remote-tracking branch 'origin' into add-azure-queue-storage 2024-06-26 13:05:56 +02:00
SystemLogBase.h Merge remote-tracking branch 'origin' into add-azure-queue-storage 2024-06-26 13:05:56 +02:00
TargetSpecific.cpp Reapply "Remove some unnecessary UNREACHABLEs" 2024-05-29 13:37:47 +00:00
TargetSpecific.h Remove old code 2024-03-04 00:11:55 +01:00
TerminalSize.cpp Refactor 2024-06-25 14:23:37 +00:00
TerminalSize.h Refactor 2024-06-25 14:23:37 +00:00
thread_local_rng.cpp
thread_local_rng.h
ThreadFuzzer.cpp Remove dependency on SettingsFields from FormatSettings 2024-07-10 19:19:10 +02:00
ThreadFuzzer.h Fix fuzzer when only explicit faults are used 2024-05-14 16:25:12 +02:00
ThreadPool_fwd.h [RFC] Try to add global Real and CPU trace collector 2024-04-02 18:04:53 +02:00
ThreadPool.cpp More fixes 2024-07-26 10:47:32 +02:00
ThreadPool.h Merge branch 'master' into try-about-on-current-thread-join 2024-06-04 18:11:34 +02:00
threadPoolCallbackRunner.h Remove wrong comment 2024-05-26 08:31:01 +00:00
ThreadPoolTaskTracker.cpp cancel tasks on exception 2024-04-04 22:32:57 +02:00
ThreadPoolTaskTracker.h cancel tasks on exception 2024-04-04 22:32:57 +02:00
ThreadProfileEvents.cpp Reapply "Remove some unnecessary UNREACHABLEs" 2024-05-29 13:37:47 +00:00
ThreadProfileEvents.h Fix clang-tidy "-readability-redundant-inline-specifier" 2024-05-19 10:23:58 +00:00
ThreadStatus.cpp Merge pull request #63632 from azat/global-query-profiler-followup 2024-05-20 08:42:25 +02:00
ThreadStatus.h Revert "Add dynamic untracked memory limits for more precise memory tracking" 2024-06-07 14:03:56 +02:00
Throttler_fwd.h
Throttler.cpp safer 2024-06-10 16:48:24 +00:00
Throttler.h Add metrics for PutObject and GetObject throttlers of ObjectStorage 2024-06-10 11:49:41 +00:00
TimerDescriptor.cpp Debug TimerDescriptor 2024-07-29 18:55:08 +02:00
TimerDescriptor.h Removed useless parameters 2024-07-27 20:50:21 +02:00
TLDListsHolder.cpp Move StringUtils.h/cpp back to Common/ 2024-05-19 09:39:36 +00:00
TLDListsHolder.h
TraceSender.cpp Fix error 2024-07-21 12:06:53 +02:00
TraceSender.h
TransactionID.cpp
TransactionID.h update fmtlib version to 9.1.0 2024-06-07 06:44:36 +00:00
transformEndianness.h Remove useless header files 2023-11-06 03:49:55 +01:00
tryGetFileNameByFileDescriptor.cpp Compress STDOUT if redirected to file with a compression extension 2024-05-13 09:21:01 +02:00
tryGetFileNameByFileDescriptor.h Compress STDOUT if redirected to file with a compression extension 2024-05-13 09:21:01 +02:00
TTLCachePolicy.h Change query cache keys from ASTs to AST hashes 2024-04-16 09:27:20 +00:00
typeid_cast.h
TypePromotion.h
UnicodeBar.cpp
UnicodeBar.h
UTF8Helpers.cpp rename forgoten isEscapeSequence to is_escape_sequence 2024-06-05 10:58:30 +02:00
UTF8Helpers.h Move isAllASCII from UTF8Helpers to StringUtils 2024-05-19 09:39:48 +00:00
VariableContext.h Useless changes 2024-05-09 01:08:33 +02:00
VersionNumber.cpp
VersionNumber.h
Visitor.h
Volnitsky.h Merge remote-tracking branch 'rschu1ze/master' into redundant-inline 2024-05-21 05:15:35 +00:00
waitForPid.cpp Initial support for loongarch64 2024-05-14 07:45:26 +00:00
waitForPid.h
WeakHash.cpp Replace updateWeakHash to getWeakHash 2024-07-17 13:23:44 +00:00
WeakHash.h Replace updateWeakHash to getWeakHash 2024-07-17 13:23:44 +00:00
XMLUtils.cpp Fix Mac 2024-01-13 04:49:50 +01:00
XMLUtils.h