ClickHouse/src/Common
Alexey Milovidov d72bc854d1
Merge pull request #57074 from ClickHouse/less-allocation-in-arenas
Avoid excessive allocation in Arena
2023-11-23 23:02:26 +01:00
..
benchmarks Disambiguate crc32 from crc32c for s390x impl. 2023-10-31 11:21:37 -07:00
Config Lint 2023-11-16 02:51:29 +03:00
examples Add metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01:00
HashTable Remove orphan header files 2023-11-14 07:43:11 +01:00
JSONParsers update 2023-09-15 16:05:17 +08:00
mysqlxx Use pcg/randomSeed() random generator/seed instead of std::mt19937/std::random_device 2023-11-07 18:54:50 +00:00
NamedCollections Merge pull request #56494 from evillique/fix-empty-named-collections 2023-11-13 17:49:17 +01: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 metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01:00
ZooKeeper Merge pull request #56460 from ClickHouse/keeper-map-backup-restore 2023-11-18 19:27:36 +01:00
ActionBlocker.h
ActionLock.cpp
ActionLock.h
AlignedBuffer.cpp
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 Fix error 2023-11-22 22:09:24 +01:00
ArenaAllocator.h Avoid excessive allocation in Arena 2023-11-22 12:13:47 +01:00
ArenaUtils.h
ArenaWithFreeLists.h
ArrayCache.h
assert_cast.h Cosmetics 2023-06-28 18:35:27 +00:00
assertProcessUserMatchesDataOwner.cpp
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
AsyncLoader.cpp Add metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01:00
AsyncLoader.h Add metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01:00
AsyncTaskExecutor.cpp Destroy fiber in case of exception in cancelBefore in AsyncTaskExecutor (#55516) 2023-10-11 21:04:43 -07:00
AsyncTaskExecutor.h
atomicRename.cpp
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 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
checkSSLReturnCode.h
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 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
CombinedCardinalityEstimator.h
CompactArray.h
Concepts.h
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 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 added macro to enable/disable pocketfft lib 2023-11-21 06:52:47 -08: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 Add metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01: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 stack symbolizer parsing DW_FORM_ref_addr incorrectly and sometimes crashing (#55483) 2023-10-11 15:27:16 -07:00
Dwarf.h Switch from DWARF 4 to 5 and see what happens (#56770) 2023-11-16 09:58:00 -08:00
ElapsedTimeProfileEventIncrement.h
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 Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy (#55033) 2023-11-04 13:47:52 -04: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 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 Merge branch 'master' of https://github.com/ClickHouse/ClickHouse into keeper-az-fix 2023-11-16 21:58:02 +00:00
ErrorCodes.h
ErrorHandlers.h
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
EventFD.h
EventNotifier.cpp
EventNotifier.h Ditch tons of garbage 2023-08-09 02:19:02 +02:00
EventRateMeter.h
Exception.cpp Fix build 2023-11-13 10:09:23 +01:00
Exception.h Miscellaneous 2023-11-13 09:06:18 +01:00
ExponentiallySmoothedCounter.h
ExternalLoaderStatus.h
ExternalModelInfo.h
FailPoint.cpp Fix typo everywhere 2023-11-03 16:40:50 +01:00
FailPoint.h Support setting up fail points in config 2023-08-31 11:45:39 +00:00
Fiber.h
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 IStorage::checkDataNext returns optional 2023-10-23 10:12:30 +00:00
FileChecker.h IStorage::checkDataNext returns optional 2023-10-23 10:12:30 +00:00
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
formatIPv6.cpp
formatIPv6.h Miscellaneous 2023-11-13 09:06:18 +01:00
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 Add load balancing test_hostname_levenshtein_distance 2023-09-27 10:46:39 +08:00
GetPriorityForLoadBalancing.h Settings pointer to reference 2023-11-21 16:04:54 +00:00
getRandomASCIIString.cpp
getRandomASCIIString.h
hasLinuxCapability.cpp
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 Remove useless header files 2023-11-06 03:49:55 +01:00
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 Add load balancing test_hostname_levenshtein_distance 2023-09-27 10:46:39 +08:00
isLocalAddress.h Add load balancing test_hostname_levenshtein_distance 2023-09-27 10:46:39 +08:00
isValidUTF8.cpp
isValidUTF8.h
JSONBuilder.cpp
JSONBuilder.h
KnownObjectNames.cpp
KnownObjectNames.h
levenshteinDistance.cpp Use levenshteinDistance for neareast hostname load balancer 2023-09-20 17:42:25 +08: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
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 Miscellaneous 2023-11-13 09:06:18 +01: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
makeSocketAddress.h
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 Fix wrong attribution of untracked memory to a user/query (#56089) 2023-11-02 17:14:15 +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 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
NamePrompter.cpp
NamePrompter.h Update src/Common/NamePrompter.h 2023-10-12 17:30:01 +02: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
ObjectStorageKey.cpp review notes 2023-11-03 22:43:40 +01:00
ObjectStorageKey.h review notes 2023-11-03 22:43:40 +01:00
OpenSSLHelpers.cpp
OpenSSLHelpers.h
OpenTelemetryTraceContext.cpp Re-enable clang-tidy checks 2023-09-26 09:34:12 +00:00
OpenTelemetryTraceContext.h
OptimizedRegularExpression.cpp Fix some typos 2023-10-15 15:43:02 +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 small fixes after review 2023-11-16 00:01:36 +01:00
parseGlobs.h Update after review 2023-11-15 16:37:24 +01:00
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
ProcfsMetricsProvider.cpp
ProcfsMetricsProvider.h
ProfileEvents.cpp Add CachedReadBufferReadFromCache{Hits,Misses} profile events 2023-11-21 10:34:12 +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 Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy (#55033) 2023-11-04 13:47:52 -04:00
ProxyConfigurationResolverProvider.h tmp 2023-10-04 17:21:41 -03:00
ProxyListConfigurationResolver.cpp Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy (#55033) 2023-11-04 13:47:52 -04:00
ProxyListConfigurationResolver.h Add ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy (#55033) 2023-11-04 13:47:52 -04:00
QueryProfiler.cpp Taming query profiler 2023-10-29 11:15:11 +01: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 Use pcg/randomSeed() random generator/seed instead of std::mt19937/std::random_device 2023-11-07 18:54:50 +00:00
randomSeed.h
register_objects.cpp
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 ClickHouse setting to disable tunneling for HTTPS requests over HTTP proxy (#55033) 2023-11-04 13:47:52 -04: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
RWLock.h
safe_cast.h
scope_guard_safe.h
SensitiveDataMasker.cpp SensitiveDataMasker: reduce the scope of mutex 2023-11-15 17:45:28 +02:00
SensitiveDataMasker.h Move mutex from Context to SensitiveDataMasker 2023-11-14 14:03:28 +02:00
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
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 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
SimpleIncrement.h
SipHash.h Remove useless header files 2023-11-06 03:49:55 +01:00
SLRUCachePolicy.h Some renamings for more consistency 2023-08-22 10:48:03 +00:00
SpaceSaving.h Fixed style. 2023-10-31 19:02:49 -07: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
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 Implement system table blob_storage_log 2023-11-21 09:18:25 +00:00
SystemLogBase.h Implement system table blob_storage_log 2023-11-21 09:18:25 +00: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 Add metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01:00
ThreadPool.h Add metrics for the number of queued jobs, which is useful for the IO thread pool 2023-11-18 19:07:59 +01: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
Throttler.h
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.h Remove useless header files 2023-11-06 03:49:55 +01:00
TTLCachePolicy.h Some renamings for more consistency 2023-08-22 10:48:03 +00:00
typeid_cast.h
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
XMLUtils.h