ClickHouse/src/Common
Alexander Tokmakov 910d6dc0ce
Merge pull request #45342 from ClickHouse/exception_message_patterns
Save message format strings for DB::Exception
2023-01-20 18:46:52 +03:00
..
benchmarks Add google benchmark to contrib (#43779) 2022-12-08 13:38:08 +01:00
Config Merge branch 'master' into faster_backup_config_loading 2022-11-29 09:43:47 +01:00
examples Add google benchmark to contrib (#43779) 2022-12-08 13:38:08 +01:00
HashTable Addressed the review comments 2023-01-11 17:00:10 -08:00
JSONParsers Allow coercing in JSONExtract* functions 2022-10-27 10:26:55 +02:00
mysqlxx Fix -Wshorten-64-to-32 for musl 2022-10-21 13:25:42 +02:00
NamedCollections Fix tests 2022-12-20 22:33:54 +01:00
StringUtils Addressed PR comments 2022-12-07 14:23:01 +00:00
tests Merge branch 'master' into ftsearch 2023-01-19 11:34:11 -05:00
ZooKeeper Merge branch 'master' into faster-startup-bc-check 2022-12-27 23:17:24 +03:00
ActionBlocker.h
ActionLock.cpp
ActionLock.h
AlignedBuffer.cpp
AlignedBuffer.h
Allocator_fwd.h
Allocator.cpp
Allocator.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
AllocatorWithMemoryTracking.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
Arena.h Fix ubsan in AggregateFunctionMinMaxAny::read with high sizes 2022-11-15 15:40:06 +01:00
ArenaAllocator.h
ArenaUtils.h
ArenaWithFreeLists.h
ArrayCache.h Fix clang-tidy warnings (from clang-15) 2022-09-10 21:38:35 +02:00
assert_cast.h
AsynchronousMetrics.cpp Ignore hwmon sensors on label read issues 2023-01-04 12:05:13 +01:00
AsynchronousMetrics.h Merge branch 'master' into keeper-prometheus 2022-11-15 12:00:02 +00:00
atomicRename.cpp
atomicRename.h
Base58.cpp Add functio ntryBase58Decode() 2022-09-27 10:18:36 +00:00
Base58.h Add functio ntryBase58Decode() 2022-09-27 10:18:36 +00:00
Base64.cpp Address PR comments 2022-09-01 07:56:06 +00:00
Base64.h Improve remove recursive 2022-09-01 12:16:13 +00:00
BinStringDecodeHelper.h Support SQL standard binary and hex string literals 2022-12-11 13:05:40 +08:00
BitHelpers.h Merge branch 'master' into pr/BigRedEye/38191 2022-09-30 09:40:47 +00:00
BridgeProtocolVersion.h Add simple versioning to the *-bridge-to-server protocol 2022-08-08 19:40:37 +00:00
CacheBase.h Delete TODO 2022-08-11 22:38:13 +00:00
CancelableSharedMutex.cpp review fixes + split into files 2023-01-09 14:58:44 +00:00
CancelableSharedMutex.h fix darwin build 2023-01-11 12:23:33 +00:00
CancelToken.cpp make style-check happy 2023-01-10 01:26:59 +00:00
CancelToken.h make style-check happy 2023-01-10 01:26:59 +00:00
CaresPTRResolver.cpp Fix build 2022-10-27 21:11:41 +00:00
CaresPTRResolver.h Make CaresPTRResolver completely thread-safe 2022-10-21 14:32:48 -03:00
checkStackSize.cpp Fix half of trash 2022-09-10 04:08:16 +02:00
checkStackSize.h
clearPasswordFromCommandLine.cpp
clearPasswordFromCommandLine.h
clickhouse_malloc.cpp Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
ClickHouseRevision.cpp Generate config_version.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
ClickHouseRevision.h
CMakeLists.txt Add google benchmark to contrib (#43779) 2022-12-08 13:38:08 +01:00
ColumnsHashing.h Prefetching in aggregation (#39304) 2022-09-21 18:59:07 +02:00
ColumnsHashingImpl.h Prefetching in aggregation (#39304) 2022-09-21 18:59:07 +02:00
CombinedCardinalityEstimator.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
CompactArray.h Fix clang-tidy in utils/examples 2022-07-29 11:36:51 +03:00
Concepts.h
ConcurrencyControl.h fix some typos and clang-tidy warnings 2022-09-05 09:50:24 +08:00
ConcurrentBoundedQueue.h Fix ConcurrentBoundedQueue::emplace() return value in case of finished queue 2023-01-03 20:36:12 +01:00
config_version.h.in Make comment consistent accross generated files 2022-09-28 08:11:09 +00:00
config.h.in Integrate skim into the client/local 2022-12-14 20:57:41 +01:00
CounterInFile.h
COW.h
CpuId.h ColumnVector: re-enable AVX512_VBMI/AVX512_VBMI2 optimized filter and index (#41765) 2022-10-24 23:11:46 +02:00
createHardLink.cpp
createHardLink.h
CurrentMemoryTracker.cpp Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
CurrentMemoryTracker.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
CurrentMetrics.cpp improve 2023-01-17 15:47:52 +01:00
CurrentMetrics.h
CurrentThread.cpp Try to optimize CurrentMemoryTracker alloc and free 2022-08-10 22:05:09 +02:00
CurrentThread.h Try to optimize CurrentMemoryTracker alloc and free 2022-08-10 22:05:09 +02:00
DateLUT.cpp Limit suppression to a specific warning 2022-08-21 18:24:17 +00:00
DateLUT.h slightly better 2022-10-04 14:19:05 +00:00
DateLUTImpl.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
DateLUTImpl.h change as request 2023-01-09 20:39:46 +08:00
DNSPTRResolver.h Fix CaresPTRResolver not reading hosts file 2022-08-29 15:11:39 -03:00
DNSPTRResolverProvider.cpp what 2022-10-21 14:43:08 -03:00
DNSPTRResolverProvider.h
DNSResolver.cpp Evict stale DNS entries from cache in case of network errors (#41707) 2022-09-25 14:06:13 +02:00
DNSResolver.h Evict stale DNS entries from cache in case of network errors (#41707) 2022-09-25 14:06:13 +02:00
Documentation.h Add Documentation to FunctionFactory 2022-08-27 22:06:57 +02:00
Dwarf.cpp Add support for DWARF-5 (without emitting them in binaries) 2022-09-11 21:06:14 +02:00
Dwarf.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
ElapsedTimeProfileEventIncrement.h Better time watch 2023-01-06 18:44:48 +01:00
Elf.cpp Improve error messages in Elf loader 2022-09-02 23:22:25 +02:00
Elf.h
Epoll.cpp Remove test logging of signal "EINTR" 2022-12-07 13:32:43 +01:00
Epoll.h
ErrorCodes.cpp review fixes + split into files 2023-01-09 14:58:44 +00:00
ErrorCodes.h
ErrorHandlers.h
escapeForFileName.cpp
escapeForFileName.h
EventCounter.h
EventFD.cpp Review fixes. 2022-11-24 16:04:35 +00:00
EventFD.h Review fixes. 2022-11-24 16:04:35 +00:00
EventNotifier.cpp Try to make MergeTreeRestartingThread more reactive in case of expired sessions (#41092) 2022-09-23 14:40:04 +02:00
EventNotifier.h Try to make MergeTreeRestartingThread more reactive in case of expired sessions (#41092) 2022-09-23 14:40:04 +02:00
EventRateMeter.h typo 2022-11-17 16:20:21 +00:00
Exception.cpp less fmt::runtime usages 2023-01-17 00:11:59 +01:00
Exception.h formatting of some exception messages 2023-01-17 20:03:56 +01:00
ExponentiallySmoothedCounter.h
ExternalLoaderStatus.h
ExternalModelInfo.h chore: restore SYSTEM RELOAD MODEL(S) and moniting view SYSTEM.MODELS 2022-09-12 19:33:02 +00:00
Fiber.h
FiberStack.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
FieldVisitorConvertToNumber.h replace domain IP types (IPv4, IPv6) with native 2022-11-14 14:17:17 +00:00
FieldVisitorDump.cpp replace domain IP types (IPv4, IPv6) with native 2022-11-14 14:17:17 +00:00
FieldVisitorDump.h replace domain IP types (IPv4, IPv6) with native 2022-11-14 14:17:17 +00:00
FieldVisitorHash.cpp replace domain IP types (IPv4, IPv6) with native 2022-11-14 14:17:17 +00:00
FieldVisitorHash.h replace domain IP types (IPv4, IPv6) with native 2022-11-14 14:17:17 +00:00
FieldVisitors.h
FieldVisitorsAccurateComparison.h
FieldVisitorSum.cpp Merge branch 'master' into refactoring-ip-types 2022-11-28 08:50:19 -05:00
FieldVisitorSum.h replace domain IP types (IPv4, IPv6) with native 2022-11-14 14:17:17 +00:00
FieldVisitorToString.cpp cleanup 2022-11-29 17:34:16 +00:00
FieldVisitorToString.h replace domain IP types (IPv4, IPv6) with native 2022-11-14 14:17:17 +00:00
FieldVisitorWriteBinary.cpp replace domain IP types (IPv4, IPv6) with native 2022-11-14 14:17:17 +00:00
FieldVisitorWriteBinary.h replace domain IP types (IPv4, IPv6) with native 2022-11-14 14:17:17 +00:00
FileChecker.cpp
FileChecker.h
filesystemHelpers.cpp Do not throw DB::Exception when folders do not exist 2023-01-03 17:05:54 +01:00
filesystemHelpers.h Temporary files evict fs cache 2022-12-22 10:22:49 +00:00
FileUpdatesTracker.h
format.h
formatIPv6.cpp review suggestions 2022-12-07 21:29:17 +00:00
formatIPv6.h fix parser 2022-12-10 06:22:49 +00:00
formatReadable.cpp
formatReadable.h
FrequencyHolder.h
FST.cpp Addressed more review comments and ClangTidy errors 2023-01-17 06:29:13 -08:00
FST.h Addressed more review comments and ClangTidy errors 2023-01-17 06:29:13 -08:00
futex.h review fixes + split into files 2023-01-09 14:58:44 +00:00
getCurrentProcessFDCount.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
getCurrentProcessFDCount.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
getExecutablePath.cpp
getExecutablePath.h dbms/ → src/ 2020-04-03 18:14:31 +03:00
getHashOfLoadedBinary.cpp
getHashOfLoadedBinary.h
getMappedArea.cpp
getMappedArea.h
getMaxFileDescriptorCount.cpp
getMaxFileDescriptorCount.h
getMultipleKeysFromConfig.cpp
getMultipleKeysFromConfig.h
getNumberOfPhysicalCPUCores.cpp Increase threshold for using physical cores (#42503) 2022-10-21 12:52:46 +02:00
getNumberOfPhysicalCPUCores.h
GetPriorityForLoadBalancing.cpp Fix stack-use-after-return in GetPriorityForLoadBalancing::getPriorityFunc() 2022-09-09 20:06:48 +02:00
GetPriorityForLoadBalancing.h
getRandomASCIIString.cpp Remove some trash 2022-08-21 20:46:33 +02:00
getRandomASCIIString.h Remove some trash 2022-08-21 20:46:33 +02:00
getResource.cpp
getResource.h
hasLinuxCapability.cpp
hasLinuxCapability.h
hex.cpp
hex.h Revert "Fix endian issue in integer hex string conversion" 2022-11-24 12:22:22 +01:00
HyperLogLogBiasEstimator.h
HyperLogLogCounter.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
HyperLogLogWithSmallSetOptimization.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
ICachePolicy.h Review fixes 2022-08-07 20:02:21 +00:00
IFactoryWithAliases.h
Increment.h
interpolate.h
InterruptListener.h
IntervalKind.cpp abort instead of __builtin_unreachable in debug builds 2022-10-07 21:49:08 +02:00
IntervalKind.h Fix typos with new codespell 2022-09-02 08:54:48 +00:00
IntervalTree.h
intExp.h Merge remote-tracking branch 'upstream/master' into build/shorten-64-to-32 2022-10-21 22:51:56 +02:00
IO.cpp
IO.h
IPv6ToBinary.cpp Use std::popcount, ::countl_zero, ::countr_zero functions 2022-07-31 15:16:51 +00:00
IPv6ToBinary.h
isLocalAddress.cpp
isLocalAddress.h
isValidUTF8.cpp
isValidUTF8.h
JSONBuilder.cpp
JSONBuilder.h
KnownObjectNames.cpp Fix style. 2022-11-16 01:35:11 +01:00
KnownObjectNames.h Move maskSensitiveInfoInQueryForLogging() to src/Parsers/ 2022-11-14 18:55:19 +01:00
LocalDate.h
LocalDateTime.h Fix call to wrong overload on Darwin 2022-12-21 09:00:44 +00:00
LockMemoryExceptionInThread.cpp
LockMemoryExceptionInThread.h
logger_useful.h save format strings for DB::Exceptions 2023-01-16 23:20:33 +01:00
LoggingFormatStringHelpers.h save format strings for DB::Exceptions 2023-01-16 23:20:33 +01:00
LRUCachePolicy.h Review fixes 2022-08-07 20:02:21 +00:00
LRUResourceCache.h Change class LRUCache to class CachBase. Check running CacheBase with default pcahce policy SLRU 2022-08-07 19:59:30 +00:00
Macros.cpp
Macros.h
malloc.cpp
memcmpSmall.h Use std::popcount, ::countl_zero, ::countr_zero functions 2022-07-31 15:16:51 +00:00
memcpySmall.h
memory.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
MemorySanitizer.h
MemoryStatisticsOS.cpp Fix -Wzero-as-null-pointer-constant in MemoryStatisticsOS::get for FreeBSD 2022-09-10 21:38:35 +02:00
MemoryStatisticsOS.h Fix -Wshorten-64-to-32 on FreeBSD 2022-12-12 08:05:28 +01:00
MemoryTracker.cpp Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
MemoryTracker.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
MemoryTrackerBlockerInThread.cpp Make only one possible public ctor in MemoryTrackerBlockerInThread 2022-07-26 19:03:26 +00:00
MemoryTrackerBlockerInThread.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
MultiVersion.h
NamePrompter.cpp Added compound types typo corrections 2022-11-10 19:21:51 +01:00
NamePrompter.h Added compound types typo corrections 2022-11-10 19:21:51 +01:00
NaNUtils.h
NetException.h
new_delete.cpp Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
noexcept_scope.h
ObjectPool.h
OpenSSLHelpers.cpp Generate config.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
OpenSSLHelpers.h Generate config.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
OpenTelemetryTraceContext.cpp Keep compatibility during upgrading 2022-09-23 11:32:21 +08:00
OpenTelemetryTraceContext.h Address review comments 2022-09-23 10:08:42 +08:00
OptimizedRegularExpression.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
OptimizedRegularExpression.h Generate config.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
OvercommitTracker.cpp Also count waiting on global mutext 2022-12-14 18:05:07 +00:00
OvercommitTracker.h fix some typos and clang-tidy warnings 2022-09-05 09:50:24 +08:00
parseAddress.cpp
parseAddress.h
parseGlobs.cpp Merge branch 'master' into 36316_Support_glob_for_recursive_directory_traversal 2022-10-24 18:34:19 +02:00
parseGlobs.h
parseRemoteDescription.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
parseRemoteDescription.h
PipeFDs.cpp Fix clang-tidy 2022-08-20 17:09:20 +02:00
PipeFDs.h
PODArray_fwd.h Adapt internal data structures to 512-bit era (#42564) 2022-10-25 13:56:28 +02:00
PODArray.cpp Adapt internal data structures to 512-bit era (#42564) 2022-10-25 13:56:28 +02:00
PODArray.h Rollback reserveForNextSize change 2022-12-07 10:29:00 +08:00
PoolBase.h
PoolWithFailoverBase.h Fix -Wshorten-64-to-32 for musl 2022-10-21 13:25:42 +02:00
ProcfsMetricsProvider.cpp
ProcfsMetricsProvider.h
ProfileEvents.cpp Merge branch 'master' into hanfei/async-cache 2023-01-18 00:19:49 +01:00
ProfileEvents.h fix tracing of profile events 2022-12-08 15:13:53 +00:00
ProfilingScopedRWLock.h
ProgressIndication.cpp Revert "Add information about written rows in progress indicator" 2022-12-15 10:19:15 +03:00
ProgressIndication.h do not reorder, ignore 4 readings, fix period 2022-11-17 15:53:47 +00:00
QueryProfiler.cpp fix tracing of profile events 2022-12-08 15:13:53 +00:00
QueryProfiler.h Generate config.h into ${CONFIG_INCLUDE_PATH} 2022-09-28 12:48:26 +00:00
quoteString.cpp
quoteString.h
RadixSort.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
randomSeed.cpp
randomSeed.h
RangeGenerator.h
register_objects.cpp Automated function registration 2022-07-29 15:39:50 +08:00
register_objects.h Automated function registration 2022-07-29 15:39:50 +08:00
remapExecutable.cpp What happens if I remove these 139 lines of code? 2023-01-03 18:35:31 +00:00
remapExecutable.h
RemoteHostFilter.cpp
RemoteHostFilter.h
RWLock.cpp
RWLock.h
safe_cast.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
scope_guard_safe.h
SensitiveDataMasker.cpp Make the password wiping an option of IAST::format(). 2022-11-16 01:35:06 +01:00
SensitiveDataMasker.h Fix style. 2022-11-16 01:35:11 +01:00
setThreadName.cpp
setThreadName.h
SettingConstraintWritability.h review fixes 2022-09-15 11:34:14 +00:00
SettingsChanges.cpp
SettingsChanges.h
SharedBlockRowRef.h
SharedMutex.cpp fix SharedMutex build 2023-01-10 16:35:46 +00:00
SharedMutex.h fix special builds 2023-01-12 01:30:42 +00:00
ShellCommand.cpp Don't be kind with third-party code 2022-12-28 20:07:26 +01:00
ShellCommand.h Don't be kind with third-party code 2022-12-28 20:07:26 +01:00
SimpleActionBlocker.h
SimpleIncrement.h
SipHash.h Merge branch 'master' into hlee-s390x-wide-int-order 2022-12-04 18:47:00 +01:00
SLRUCachePolicy.h Fix half of trash 2022-09-10 04:08:16 +02:00
SmallObjectPool.h
SpaceSaving.h Use std::popcount, ::countl_zero, ::countr_zero functions 2022-07-31 15:16:51 +00:00
StackTrace.cpp Merge pull request #40422 from pkubaj/patch-1 2022-12-11 09:38:04 +03:00
StackTrace.h Allow to hide addresses in stack traces 2022-07-29 00:13:02 +02:00
StatusFile.cpp Fix style 2022-08-20 17:59:51 +02:00
StatusFile.h
StatusInfo.cpp
StatusInfo.h
Stopwatch.h Unify query elapsed time measurements (#43455) 2022-12-28 21:01:41 +01:00
StringSearcher.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
StudentTTest.cpp
StudentTTest.h Fix half of trash 2022-09-10 04:08:16 +02:00
SymbolIndex.cpp Make getResource() independent from the order of the sections 2022-10-24 07:10:45 +02:00
SymbolIndex.h Make getResource() independent from the order of the sections 2022-10-24 07:10:45 +02:00
SystemLogBase.cpp add system table asynchronous_inserts_log 2022-10-03 21:35:55 +00:00
SystemLogBase.h add system table asynchronous_inserts_log 2022-10-03 21:35:55 +00:00
TargetSpecific.cpp ColumnVector: re-enable AVX512_VBMI/AVX512_VBMI2 optimized filter and index (#41765) 2022-10-24 23:11:46 +02:00
TargetSpecific.h ColumnVector: re-enable AVX512_VBMI/AVX512_VBMI2 optimized filter and index (#41765) 2022-10-24 23:11:46 +02:00
TaskStatsInfoGetter.cpp less empty patterns 2023-01-17 01:19:44 +01:00
TaskStatsInfoGetter.h
TerminalSize.cpp
TerminalSize.h
thread_local_rng.cpp
thread_local_rng.h
ThreadFuzzer.cpp fix race between INSERT and ALTER PARTITION 2022-11-02 16:25:26 +01:00
ThreadFuzzer.h fix race between INSERT and ALTER PARTITION 2022-11-02 16:25:26 +01:00
ThreadPool.cpp Call std::condition_variable::notify_one w/o lock in ThreadPool 2022-12-21 13:50:03 +08:00
ThreadPool.h Merge pull request #42577 from ClickHouse/clean-thread-id 2022-10-24 12:03:28 +02:00
ThreadProfileEvents.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
ThreadProfileEvents.h Add sanity checks RUsageCounters::incrementProfileEvents() 2022-11-18 21:10:43 +01:00
ThreadStatus.cpp Optimizations around ThreadStatus 2022-10-13 21:49:21 +02:00
ThreadStatus.h Merge branch 'master' into perf_experiment 2022-11-24 10:32:12 +01:00
Throttler_fwd.h
Throttler.cpp Revert "Revert "S3 request per second rate throttling"" 2022-11-17 17:35:04 +01:00
Throttler.h Revert "Revert "S3 request per second rate throttling"" 2022-11-17 17:35:04 +01:00
TimerDescriptor.cpp Remove logging from TimerDescriptor 2022-12-07 13:33:29 +01:00
TimerDescriptor.h
TLDListsHolder.cpp Add support of !/* (exclamation/asterisk) in custom TLDs 2022-07-26 08:34:30 +03:00
TLDListsHolder.h Add support of !/* (exclamation/asterisk) in custom TLDs 2022-07-26 08:34:30 +03:00
TraceSender.cpp Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
TraceSender.h Revert "Merge pull request #38953 from ClickHouse/add-allocation-ptr-to-trace-log" 2022-12-27 14:28:13 +01:00
TransactionID.cpp
TransactionID.h
typeid_cast.h fixed some bugs, some functions corrected, some tests corrected 2022-11-18 20:10:27 +00:00
TypePromotion.h
UnicodeBar.cpp Fixed unused value warning 2022-12-21 10:55:20 +01:00
UnicodeBar.h Check remaining space to avoid buffer overruns; some cleanups 2022-12-20 02:39:44 +01:00
UTF8Helpers.cpp Use std::popcount, ::countl_zero, ::countr_zero functions 2022-07-31 15:16:51 +00:00
UTF8Helpers.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
VariableContext.h
VersionNumber.cpp Fix half of trash 2022-09-10 04:08:16 +02:00
VersionNumber.h
Visitor.h
Volnitsky.h Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
waitForPid.cpp Fixes for -Wshorten-64-to-32 2022-10-21 13:25:19 +02:00
waitForPid.h ShellCommand wait pid refactoring 2022-07-21 11:45:09 +02:00
WeakHash.cpp
WeakHash.h
XMLUtils.cpp Followup fixes for XML helpers (#43845) 2022-12-01 13:36:40 +01:00
XMLUtils.h Followup fixes for XML helpers (#43845) 2022-12-01 13:36:40 +01:00